Searched refs:task (Results 151 - 175 of 688) sorted by relevance

1234567891011>>

/external/chromium_org/base/message_loop/
H A Dmessage_loop_proxy_impl.h29 const base::Closure& task,
33 const base::Closure& task,
H A Dincoming_task_queue.cc23 const Closure& task,
28 from_here, task, CalculateDelayedRuntime(delay), nestable);
30 // We consider the task needs a high resolution timer if the delay is
89 // directly, as it could starve handling of foreign threads. Put every task
96 pending_task->task.Reset();
102 // delayed_run_time value) and for identifying the task in about:tracing.
110 pending_task->task.Reset();
21 AddToIncomingQueue( const tracked_objects::Location& from_here, const Closure& task, TimeDelta delay, bool nestable) argument
/external/chromium_org/base/task/
H A Dcancelable_task_tracker.cc5 #include "base/task/cancelable_task_tracker.h"
26 void RunIfNotCanceled(const CancellationFlag* flag, const Closure& task) { argument
28 task.Run();
32 const Closure& task,
34 RunIfNotCanceled(flag, task);
74 const Closure& task) {
77 return PostTaskAndReply(task_runner, from_here, task, Bind(&base::DoNothing));
83 const Closure& task,
100 Bind(&RunIfNotCanceled, flag, task),
149 // 1. The task ha
31 RunIfNotCanceledThenUntrack(const CancellationFlag* flag, const Closure& task, const Closure& untrack) argument
71 PostTask( TaskRunner* task_runner, const tracked_objects::Location& from_here, const Closure& task) argument
80 PostTaskAndReply( TaskRunner* task_runner, const tracked_objects::Location& from_here, const Closure& task, const Closure& reply) argument
[all...]
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/
H A Dtask_runner_util.h58 const Callback<TaskReturnType(void)>& task,
63 base::Bind(&internal::ReturnAsParamAdapter<TaskReturnType>, task,
55 PostTaskAndReplyWithResult( TaskRunner* task_runner, const tracked_objects::Location& from_here, const Callback<TaskReturnType(void)>& task, const Callback<void(ReplyArgType)>& reply) argument
/external/chromium_org/base/test/
H A Dtest_simple_task_runner.h51 const Closure& task,
55 const Closure& task,
67 // Runs each current pending task in order and clears the queue.
/external/chromium_org/cc/resources/
H A Draster_worker_pool.h37 // Utility function that can be used to create a "raster finished" task that
44 // each task in |graph|.
48 // Utility function that can be used to build a task graph. Inserts a node
49 // that represents |task| in |graph|. See TaskGraph definition for valid
52 RasterizerTask* task,
56 // Utility function that can be used to build a task graph. Inserts nodes that
57 // represent |task| and all its image decode dependencies in |graph|.
60 RasterTask* task,
/external/chromium_org/chrome/browser/resources/sync_file_system_internals/
H A Dmain.css43 .task-log-details label {
47 .task-log-collapse-check {
51 .task-log-collapse-check ~ ul {
61 .task-log-collapse-check:checked ~ ul {
/external/chromium_org/chrome/browser/sync/glue/
H A Dextension_setting_data_type_controller.cc49 const base::Closure& task) {
51 return BrowserThread::PostTask(BrowserThread::FILE, from_here, task);
47 PostTaskOnBackendThread( const tracked_objects::Location& from_here, const base::Closure& task) argument
H A Dpassword_data_type_controller.cc43 const base::Closure& task) {
47 return password_store_->ScheduleTask(task);
41 PostTaskOnBackendThread( const tracked_objects::Location& from_here, const base::Closure& task) argument
/external/chromium_org/content/child/
H A Dwebthread_impl.cc63 void WebThreadImpl::postTask(Task* task) { argument
65 FROM_HERE, base::Bind(&blink::WebThread::Task::run, base::Owned(task)));
68 void WebThreadImpl::postDelayedTask(Task* task, long long delay_ms) { argument
71 base::Bind(&blink::WebThread::Task::run, base::Owned(task)),
104 void WebThreadImplForMessageLoop::postTask(Task* task) { argument
106 FROM_HERE, base::Bind(&blink::WebThread::Task::run, base::Owned(task)));
109 void WebThreadImplForMessageLoop::postDelayedTask(Task* task, argument
113 base::Bind(&blink::WebThread::Task::run, base::Owned(task)),
H A Dworker_task_runner.h23 bool PostTask(int id, const base::Closure& task);
24 int PostTaskToAllThreads(const base::Closure& task);
/external/chromium_org/media/cast/test/
H A Dfake_single_thread_task_runner.h32 const base::Closure& task,
40 const base::Closure& task,
H A Dskewed_single_thread_task_runner.h20 // the delay for any posted task by a factor. The factor is changed by
21 // calling SetSkew(). A skew of 2.0 means that all delayed task will
33 const base::Closure& task,
41 const base::Closure& task,
/external/chromium_org/mojo/services/html_viewer/
H A Dwebthread_impl.cc63 void WebThreadImpl::postTask(Task* task) { argument
65 FROM_HERE, base::Bind(&blink::WebThread::Task::run, base::Owned(task)));
68 void WebThreadImpl::postDelayedTask(Task* task, long long delay_ms) { argument
71 base::Bind(&blink::WebThread::Task::run, base::Owned(task)),
103 void WebThreadImplForMessageLoop::postTask(Task* task) { argument
105 FROM_HERE, base::Bind(&blink::WebThread::Task::run, base::Owned(task)));
108 void WebThreadImplForMessageLoop::postDelayedTask(Task* task, argument
112 base::Bind(&blink::WebThread::Task::run, base::Owned(task)),
/external/chromium_org/remoting/base/
H A Dauto_thread_task_runner.h17 // management, by posting a caller-supplied task to the underlying task runner
30 const base::Closure& task,
34 const base::Closure& task,
44 // The wrapped task runner.
/external/chromium_org/storage/browser/quota/
H A Dquota_task.h35 // The task body.
41 // Called when the task is aborted.
71 void RegisterTask(QuotaTask* task);
72 void UnregisterTask(QuotaTask* task);
/external/chromium_org/third_party/WebKit/Source/core/dom/
H A DMicrotask.cpp51 // Ensure that end-of-task-or-microtask actions are performed.
65 OwnPtr<WebThread::Task> task = adoptPtr(static_cast<WebThread::Task*>(data)); local
66 task->run();
/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/webrtc/base/
H A Dtaskparent.h36 bool IsChildTask(Task *task);
40 void OnStopped(Task *task);
/external/chromium_org/v8/src/libplatform/
H A Ddefault-platform.h15 #include "src/libplatform/task-queue.h"
37 Task* task, ExpectedRuntime expected_runtime) OVERRIDE;
39 Task* task) OVERRIDE;
H A Dtask-queue.cc5 #include "src/libplatform/task-queue.h"
22 void TaskQueue::Append(Task* task) { argument
25 task_queue_.push(task);
/external/smali/util/
H A Dbuild.gradle39 task sourcesJar(type: Jar) {
/external/chromium_org/chrome/browser/sync_file_system/drive_backend/
H A Dsync_task_manager.cc24 explicit SyncTaskAdapter(const SyncTaskManager::Task& task) : task_(task) {} argument
42 const base::Closure& task, Priority pri, int seq)
43 : task(task), priority(pri), seq(seq) {}
81 const Task& task,
87 scoped_ptr<SyncTask>(new SyncTaskAdapter(task)),
94 scoped_ptr<SyncTask> task,
103 base::Passed(&task), priority, callback),
107 RunTask(token.Pass(), task
41 PendingTask( const base::Closure& task, Priority pri, int seq) argument
79 ScheduleTask( const tracked_objects::Location& from_here, const Task& task, Priority priority, const SyncStatusCallback& callback) argument
92 ScheduleSyncTask( const tracked_objects::Location& from_here, scoped_ptr<SyncTask> task, Priority priority, const SyncStatusCallback& callback) argument
110 ScheduleTaskIfIdle( const tracked_objects::Location& from_here, const Task& task, const SyncStatusCallback& callback) argument
122 ScheduleSyncTaskIfIdle( const tracked_objects::Location& from_here, scoped_ptr<SyncTask> task, const SyncStatusCallback& callback) argument
223 scoped_ptr<SyncTask> task; local
363 RunTask(scoped_ptr<SyncTaskToken> token, scoped_ptr<SyncTask> task) argument
[all...]
/external/chromium_org/chromecast/media/cma/base/
H A Dmedia_task_runner.h22 // Post a task with the given media |timestamp|. If |timestamp| is equal to
23 // |kNoTimestamp()|, the task is scheduled right away.
24 // How the media timestamp is used to schedule the task is an implementation
26 // Returns true if the task may be run at some point in the future, and false
27 // if the task definitely will not be run.
30 const base::Closure& task,

Completed in 425 milliseconds

1234567891011>>