Searched defs:task (Results 51 - 75 of 399) sorted by relevance

1234567891011>>

/external/chromium_org/sync/internal_api/attachments/
H A Dtask_queue_unittest.cc40 void Process(const int& task) { dispatched_.push_back(task); } argument
48 // See that at most one task is dispatched at a time.
148 // Try a different task. See the timer remains unchanged because the previous
149 // task was cancelled.
166 // Add one last task and see that it's dispatched without delay because the
/external/chromium_org/third_party/WebKit/Source/bindings/core/v8/
H A DScriptStreamerThread.cpp38 void ScriptStreamerThread::postTask(WebThread::Task* task) argument
44 platformThread().postTask(task);
61 ScriptStreamingTask::ScriptStreamingTask(v8::ScriptCompiler::ScriptStreamingTask* task, ScriptStreamer* streamer) argument
62 : m_v8Task(adoptPtr(task)), m_streamer(streamer) { }
67 // Running the task can and will block: SourceStream::GetSomeData will get
70 // Post a task to the main thread to signal that V8 has completed the
/external/chromium_org/third_party/WebKit/Source/platform/exported/
H A DWebSchedulerProxy.cpp18 void runTask(PassOwnPtr<WebThread::Task> task) argument
20 task->run();
40 void WebSchedulerProxy::postInputTask(const WebTraceLocation& webLocation, WebThread::Task* task) argument
43 m_scheduler->postInputTask(location, bind(&runTask, adoptPtr(task)));
46 void WebSchedulerProxy::postCompositorTask(const WebTraceLocation& webLocation, WebThread::Task* task) argument
49 m_scheduler->postCompositorTask(location, bind(&runTask, adoptPtr(task)));
52 void WebSchedulerProxy::postIpcTask(const WebTraceLocation& webLocation, WebThread::Task* task) argument
55 m_scheduler->postIpcTask(location, bind(&runTask, adoptPtr(task)));
/external/chromium_org/third_party/WebKit/Source/web/
H A DWebWorkerRunLoop.cpp36 static PassOwnPtr<TaskForwarder> create(PassOwnPtr<WebWorkerRunLoop::Task> task) argument
38 return adoptPtr(new TaskForwarder(task));
47 TaskForwarder(PassOwnPtr<WebWorkerRunLoop::Task> task) argument
48 : m_task(task)
62 bool WebWorkerRunLoop::postTask(Task* task) argument
64 m_workerThread->postTask(TaskForwarder::create(adoptPtr(task)));
/external/chromium_org/third_party/WebKit/Source/wtf/
H A DMallocZoneSupport.h41 RemoteMemoryReader(task_t task, memory_reader_t* reader) argument
42 : m_task(task)
/external/chromium_org/third_party/libaddressinput/src/cpp/src/
H A Dondemand_supplier.cc44 OndemandSupplyTask* task = local
57 task->hierarchy_.rule[depth] = it->second;
59 task->Queue(key); // If not in the cache, it needs to be loaded.
64 task->Retrieve(*retriever_);
/external/chromium_org/third_party/webrtc/base/
H A Dtaskparent.cc15 #include "webrtc/base/task.h"
47 bool TaskParent::IsChildTask(Task *task) { argument
48 ASSERT(task != NULL);
49 return task->parent_ == this && children_->find(task) != children_->end();
84 void TaskParent::OnStopped(Task *task) { argument
86 parent_->OnChildStopped(task);
H A Dtaskrunner.h41 void StartTask(Task *task);
45 void UpdateTaskTimeout(Task *task, int64 previous_task_timeout_time);
48 bool is_ok_to_delete(Task* task) { argument
49 return task == deleting_task_;
61 // Returns the next absolute time when a task times out
/external/chromium_org/ui/views_content_client/
H A Dviews_content_client.h63 // The task to run at the end of BrowserMainParts::PreMainMessageLoopRun().
65 void set_task(const Task& task) { task_ = task; } argument
66 const Task& task() const { return task_; } function in class:ui::ViewsContentClient
/external/emma/ant/ant14/com/vladium/emma/ant/
H A DGenericCfg.java41 public GenericCfg (final Task task) argument
43 if (task == null) throw new IllegalArgumentException ("null input: task");
45 m_task = task;
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/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/guava/guava/src/com/google/common/util/concurrent/
H A DListeningExecutorService.java37 * @return a {@code ListenableFuture} representing pending completion of the task
41 <T> ListenableFuture<T> submit(Callable<T> task); argument
44 * @return a {@code ListenableFuture} representing pending completion of the task
48 ListenableFuture<?> submit(Runnable task); argument
51 * @return a {@code ListenableFuture} representing pending completion of the task
55 <T> ListenableFuture<T> submit(Runnable task, T result); argument
63 * sequential order as produced by the iterator for the given task list, each of which has
66 * @throws NullPointerException if any task is null
78 * sequential order as produced by the iterator for the given task list. If the operation
79 * did not time out, each task wil
[all...]
/external/guava/guava-tests/test/com/google/common/eventbus/
H A DAsyncEventBusTest.java53 // Now we find the task in our Executor and explicitly activate it.
55 assertEquals("One event dispatch task should be queued.", 1, tasks.size());
74 public void execute(Runnable task) { argument
75 tasks.add(task);
/external/chromium_org/base/
H A Ddeferred_sequenced_task_runner.cc30 const Closure& task,
35 return target_task_runner_->PostDelayedTask(from_here, task, delay);
38 QueueDeferredTask(from_here, task, delay, false /* is_non_nestable */);
48 const Closure& task,
54 task,
57 QueueDeferredTask(from_here, task, delay, true /* is_non_nestable */);
63 const Closure& task,
68 deferred_task.task = task;
82 const DeferredTask& task local
28 PostDelayedTask( const tracked_objects::Location& from_here, const Closure& task, TimeDelta delay) argument
46 PostNonNestableDelayedTask( const tracked_objects::Location& from_here, const Closure& task, TimeDelta delay) argument
61 QueueDeferredTask( const tracked_objects::Location& from_here, const Closure& task, TimeDelta delay, bool is_non_nestable) argument
[all...]
H A Dtask_runner.cc24 const Closure& task) OVERRIDE;
37 const Closure& task) {
38 return destination_->PostTask(from_here, task);
44 const Closure& task) {
45 return PostDelayedTask(from_here, task, base::TimeDelta());
50 const Closure& task,
53 from_here, task, reply);
35 PostTask( const tracked_objects::Location& from_here, const Closure& task) argument
43 PostTask(const tracked_objects::Location& from_here, const Closure& task) argument
48 PostTaskAndReply( const tracked_objects::Location& from_here, const Closure& task, const Closure& reply) argument
/external/chromium_org/base/task/
H A Dcancelable_task_tracker.h6 // TaskRunner, and is able to cancel the task later if it's not needed
10 // Each cancelable task can be associated with a reply (also a Closure). After
11 // the task is run on the TaskRunner, |reply| will be posted back to
17 // preferred solutions for canceling a task. However, they don't support
19 // requirement. E.g. We need to cancel database lookup task on DB thread when
21 // cancelation of a task, then CancelableTaskTracker is appropriate,
28 // task. It's safe to destroy a CancelableTaskTracker while there
32 // 2. Both task and reply are deleted on the originating thread.
71 const base::Closure& task);
75 const base::Closure& task,
79 PostTaskAndReplyWithResult( base::TaskRunner* task_runner, const tracked_objects::Location& from_here, const base::Callback<TaskReturnType(void)>& task, const base::Callback<void(ReplyArgType)>& reply) argument
[all...]
/external/chromium_org/base/test/
H A Dtest_pending_task.cc15 const Closure& task,
20 task(task),
68 std::ostream& operator<<(std::ostream& os, const TestPendingTask& task) { argument
69 PrintTo(task, &os);
73 void PrintTo(const TestPendingTask& task, std::ostream* os) { argument
74 *os << task.ToString();
13 TestPendingTask( const tracked_objects::Location& location, const Closure& task, TimeTicks post_time, TimeDelta delay, TestNestability nestability) argument
H A Dtest_simple_task_runner.cc19 const Closure& task,
23 TestPendingTask(from_here, task, TimeTicks(), delay,
30 const Closure& task,
34 TestPendingTask(from_here, task, TimeTicks(), delay,
72 it->task.Run();
17 PostDelayedTask( const tracked_objects::Location& from_here, const Closure& task, TimeDelta delay) argument
28 PostNonNestableDelayedTask( const tracked_objects::Location& from_here, const Closure& task, TimeDelta delay) argument
/external/chromium_org/cc/trees/
H A Dblocking_task_runner.cc35 const base::Closure& task) {
39 return task_runner_->PostTask(from_here, task);
40 captured_tasks_.push_back(task);
34 PostTask(const tracked_objects::Location& from_here, const base::Closure& task) argument
/external/chromium_org/chrome/browser/sync/glue/
H A Dautofill_data_type_controller.cc55 const base::Closure& task) {
57 return BrowserThread::PostTask(BrowserThread::DB, from_here, task);
53 PostTaskOnBackendThread( const tracked_objects::Location& from_here, const base::Closure& task) argument
H A Dautofill_profile_data_type_controller.cc75 const base::Closure& task) {
77 return BrowserThread::PostTask(BrowserThread::DB, from_here, task);
73 PostTaskOnBackendThread( const tracked_objects::Location& from_here, const base::Closure& task) argument
/external/chromium_org/chrome/browser/sync_file_system/local/
H A Dsyncable_file_operation_runner.cc21 SyncableFileOperationRunner::Task* task) {
22 task->Cancel();
23 delete task;
69 void SyncableFileOperationRunner::PostOperationTask(scoped_ptr<Task> task) { argument
71 pending_tasks_.push_back(task.release());
82 scoped_ptr<Task> task(*iter);
84 task->Start(sync_status());
20 CancelAndDelete( SyncableFileOperationRunner::Task* task) argument
/external/chromium_org/components/domain_reliability/
H A Ddispatcher.cc58 Task* task = new Task(closure, time_->CreateTimer(), min_delay, max_delay); local
59 tasks_.insert(task);
61 RunAndDeleteTask(task);
63 MakeTaskEligible(task);
65 MakeTaskWaiting(task);
71 // keeps RunEligibleTasks from running forever if a task adds a new, already-
72 // eligible task that does the same, and so on.)
79 Task* task = *it; local
80 DCHECK(task);
81 DCHECK(task
86 MakeTaskWaiting(Task* task) argument
98 MakeTaskEligible(Task* task) argument
110 RunAndDeleteTask(Task* task) argument
[all...]
/external/chromium_org/components/webdata/common/
H A Dweb_data_service_backend.cc72 const WebDatabaseService::WriteTask& task,
77 ExecuteWriteTask(task);
82 const WebDatabaseService::WriteTask& task) {
85 WebDatabase::State state = task.Run(db_.get());
92 const WebDatabaseService::ReadTask& task,
97 request->SetResult(ExecuteReadTask(task).Pass());
102 const WebDatabaseService::ReadTask& task) {
105 return task.Run(db_.get());
71 DBWriteTaskWrapper( const WebDatabaseService::WriteTask& task, scoped_ptr<WebDataRequest> request) argument
81 ExecuteWriteTask( const WebDatabaseService::WriteTask& task) argument
91 DBReadTaskWrapper( const WebDatabaseService::ReadTask& task, scoped_ptr<WebDataRequest> request) argument
101 ExecuteReadTask( const WebDatabaseService::ReadTask& task) argument

Completed in 8905 milliseconds

1234567891011>>