Searched refs:task (Results 1 - 25 of 261) sorted by relevance

1234567891011

/external/chromium/base/threading/
H A Dworker_pool_win.cc8 #include "base/task.h"
15 Task* task = static_cast<Task*>(param); local
16 task->Run();
17 delete task;
24 Task* task, bool task_is_slow) {
25 task->SetBirthPlace(from_here);
31 if (!QueueUserWorkItem(WorkItemCallback, task, flags)) {
33 delete task;
23 PostTask(const tracked_objects::Location& from_here, Task* task, bool task_is_slow) argument
H A Dworker_pool_posix.cc11 #include "base/task.h"
29 void PostTask(const tracked_objects::Location& from_here, Task* task,
46 Task* task, bool task_is_slow) {
47 task->SetBirthPlace(from_here);
48 pool_->PostTask(task);
77 Task* task = pool_->WaitForTask(); local
78 if (!task)
80 task->Run();
81 delete task;
91 Task* task, boo
45 PostTask(const tracked_objects::Location& from_here, Task* task, bool task_is_slow) argument
90 PostTask(const tracked_objects::Location& from_here, Task* task, bool task_is_slow) argument
108 Task* task = tasks_.front(); local
123 PostTask(Task* task) argument
164 Task* task = tasks_.front(); local
[all...]
H A Dworker_pool.h26 // This function posts |task| to run on a worker thread. |task_is_slow|
28 // false if |task| could not be posted to a worker thread. Regardless of
29 // return value, ownership of |task| is transferred to the worker pool.
31 Task* task, bool task_is_slow);
/external/chromium/base/
H A Dtask_queue.cc18 void TaskQueue::Push(Task* task) { argument
19 DCHECK(task);
21 // Add the task to the back of the queue.
22 queue_.push_back(task);
43 std::deque<Task*>::const_iterator task; local
44 for (task = ready.begin(); task != ready.end(); ++task) {
45 // Run the task and then delete it.
46 (*task)
[all...]
H A Dmessage_loop_proxy_impl.cc22 Task* task) {
23 return PostTaskHelper(from_here, task, 0, true);
27 const tracked_objects::Location& from_here, Task* task, int64 delay_ms) {
28 return PostTaskHelper(from_here, task, delay_ms, true);
32 const tracked_objects::Location& from_here, Task* task) {
33 return PostTaskHelper(from_here, task, 0, false);
38 Task* task,
40 return PostTaskHelper(from_here, task, delay_ms, false);
85 const tracked_objects::Location& from_here, Task* task, int64 delay_ms,
92 target_message_loop_->PostDelayedTask(from_here, task, delay_m
21 PostTask(const tracked_objects::Location& from_here, Task* task) argument
26 PostDelayedTask( const tracked_objects::Location& from_here, Task* task, int64 delay_ms) argument
31 PostNonNestableTask( const tracked_objects::Location& from_here, Task* task) argument
36 PostNonNestableDelayedTask( const tracked_objects::Location& from_here, Task* task, int64 delay_ms) argument
84 PostTaskHelper( const tracked_objects::Location& from_here, Task* task, int64 delay_ms, bool nestable) argument
[all...]
H A Dmessage_loop_proxy_impl.h26 Task* task);
28 Task* task, int64 delay_ms);
30 Task* task);
33 Task* task,
48 Task* task, int64 delay_ms, bool nestable);
/external/webkit/Source/WebCore/platform/graphics/chromium/cc/
H A DCCMainThread.cpp36 Task* task = static_cast<Task*>(userdata); local
37 task->performTask();
38 delete task;
41 void CCMainThread::postTask(PassOwnPtr<Task> task) argument
43 callOnMainThread(performTask, task.leakPtr());
/external/guava/guava-tests/test/com/google/common/util/concurrent/
H A DListenableFutureTaskTest.java43 protected final ListenableFutureTask<Integer> task = field in class:ListenableFutureTaskTest
62 task.addListener(new Runnable() {
83 assertFalse(task.isDone());
84 assertFalse(task.isCancelled());
86 // Start the task to put it in the RUNNING state. Have to use a separate
87 // thread because the task will block on the task latch after unblocking
89 exec.execute(task);
92 assertFalse(task.isDone());
93 assertFalse(task
[all...]
/external/webkit/Tools/DumpRenderTree/chromium/
H A DTask.cpp44 void TaskList::unregisterTask(WebTask* task) argument
46 size_t index = m_tasks.find(task);
59 WebTask* task = static_cast<WebTask*>(context); local
60 task->run();
61 delete task;
64 void postTask(WebTask* task) argument
66 WebKit::webKitClient()->callOnMainThread(invokeTask, static_cast<void*>(task));
69 void postDelayedTask(WebTask* task, int64_t ms) argument
71 webkit_support::PostDelayedTask(task, ms);
/external/guava/guava/src/com/google/common/util/concurrent/
H A DForwardingListeningExecutorService.java39 public <T> ListenableFuture<T> submit(Callable<T> task) { argument
40 return delegate().submit(task);
44 public ListenableFuture<?> submit(Runnable task) { argument
45 return delegate().submit(task);
49 public <T> ListenableFuture<T> submit(Runnable task, T result) { argument
50 return delegate().submit(task, result);
/external/webkit/Tools/BuildSlaveSupport/win/
H A Dkill-old-processes54 for task in tasksToKill:
55 os.system("taskkill /t /f /im " + task)
/external/chromium/third_party/libjingle/source/talk/base/
H A Dtaskrunner.cc34 #include "talk/base/task.h"
56 void TaskRunner::StartTask(Task * task) { argument
57 tasks_.push_back(task);
59 // the task we just started could be about to timeout --
60 // make sure our "next timeout task" is correct
61 UpdateTaskTimeout(task, 0);
75 // Subsequent use of those task may cause data corruption or crashes.
101 Task* task = tasks_[i]; local
103 task->unique_id() == next_timeout_task_->unique_id()) {
109 deleting_task_ = task;
169 UpdateTaskTimeout(Task* task, int64 previous_task_timeout_time) argument
214 Task *task = tasks_[i]; local
[all...]
H A Dtaskrunner.h58 void StartTask(Task *task);
62 void UpdateTaskTimeout(Task *task, int64 previous_task_timeout_time);
65 bool is_ok_to_delete(Task* task) { argument
66 return task == deleting_task_;
78 // Returns the next absolute time when a task times out
/external/apache-xml/src/main/java/org/apache/xml/utils/
H A DThreadControllerWrapper.java38 public static void waitThread(Thread worker, Runnable task) argument
41 m_tpool.waitThread(worker, task);
54 * Will get a thread from the pool, execute the task
60 * NEEDSDOC @param task
61 * @param priority if >0 the task will run with the given priority
63 * @return The thread that is running the task, can be used
66 public Thread run(Runnable task, int priority) argument
69 Thread t = new Thread(task);
79 * Wait until the task is completed on the worker
83 * NEEDSDOC @param task
87 waitThread(Thread worker, Runnable task) argument
[all...]
/external/kernel-headers/original/linux/
H A Dioprio.h48 static inline int task_ioprio(struct task_struct *task) argument
50 WARN_ON(!ioprio_valid(task->ioprio));
51 return IOPRIO_PRIO_DATA(task->ioprio);
54 static inline int task_nice_ioprio(struct task_struct *task) argument
56 return (task_nice(task) + 20) / 5;
H A Ddebug_locks.h48 extern void debug_show_held_locks(struct task_struct *task);
50 extern void debug_check_no_locks_held(struct task_struct *task);
56 static inline void debug_show_held_locks(struct task_struct *task) argument
66 debug_check_no_locks_held(struct task_struct *task) argument
H A Dsmp_lock.h33 static inline int reacquire_kernel_lock(struct task_struct *task) argument
35 if (unlikely(task->lock_depth >= 0))
47 #define release_kernel_lock(task) do { } while(0)
48 #define reacquire_kernel_lock(task) 0
H A Dstacktrace.h11 struct task_struct *task, int all_contexts,
16 # define save_stack_trace(trace, task, all, skip) do { } while (0)
/external/jmonkeyengine/engine/src/core/com/jme3/scene/control/
H A DUpdateControl.java61 * Enqueues a task/callable object to execute in the jME3
65 AppTask<V> task = new AppTask<V>(callable);
66 taskQueue.add(task);
67 return task;
72 AppTask<?> task = taskQueue.poll();
74 if (task == null) break;
75 while (task.isCancelled()) {
76 task = taskQueue.poll();
77 if (task == null) break toploop;
79 task
[all...]
/external/emma/ant/ant14/com/vladium/emma/
H A DemmaTask.java50 final NestedTask task = (NestedTask) m_tasks.remove (0);
55 setTaskName (task.getTaskName ());
57 task.execute ();
86 protected NestedTask addTask (final NestedTask task, final String pseudoName) argument
88 initTask (task, pseudoName);
90 m_tasks.add (task);
91 return task;
94 protected void initTask (final NestedTask task, final String pseudoName) argument
96 task.setTaskName (pseudoName);
97 task
[all...]
/external/kernel-headers/original/asm-mips/
H A Dcurrent.h18 return current_thread_info()->task;
/external/webkit/Source/WebCore/wml/
H A DWMLAnchorElement.cpp71 void WMLAnchorElement::registerTask(WMLTaskElement* task) argument
74 m_task = task;
77 void WMLAnchorElement::deregisterTask(WMLTaskElement* task) argument
79 ASSERT_UNUSED(task, m_task == task);
/external/emma/ant/ant14/com/vladium/emma/ant/
H A DStringValue.java47 protected StringValue (final Task task) argument
49 if (task == null) throw new IllegalArgumentException ("null input: task");
51 m_task = task;
/external/webkit/Source/WebCore/storage/
H A DDatabaseThread.cpp106 while (OwnPtr<DatabaseTask> task = m_queue.waitForMessage()) {
107 task->performTask();
157 void DatabaseThread::scheduleTask(PassOwnPtr<DatabaseTask> task) argument
159 ASSERT(!task->hasSynchronizer() || task->hasCheckedForTermination());
160 m_queue.append(task);
163 void DatabaseThread::scheduleImmediateTask(PassOwnPtr<DatabaseTask> task) argument
165 ASSERT(!task->hasSynchronizer() || task->hasCheckedForTermination());
166 m_queue.prepend(task);
[all...]
/external/kernel-headers/original/linux/sunrpc/
H A Dxprt.h72 struct rpc_task * rq_task; /* RPC task data */
106 int (*reserve_xprt)(struct rpc_task *task);
107 void (*release_xprt)(struct rpc_xprt *xprt, struct rpc_task *task);
109 void (*connect)(struct rpc_task *task);
110 void * (*buf_alloc)(struct rpc_task *task, size_t size);
111 void (*buf_free)(struct rpc_task *task);
112 int (*send_request)(struct rpc_task *task);
113 void (*set_retrans_timeout)(struct rpc_task *task);
114 void (*timer)(struct rpc_task *task);
115 void (*release_request)(struct rpc_task *task);
[all...]

Completed in 542 milliseconds

1234567891011