HomeSort by relevance Sort by last modified time
    Searched refs:task (Results 176 - 200 of 940) sorted by null

1 2 3 4 5 6 78 91011>>

  /external/chromium_org/chrome/browser/sync/glue/
password_data_type_controller.cc 43 const base::Closure& task) {
47 return password_store_->ScheduleTask(task);
  /external/chromium_org/content/child/
webthread_impl.cc 63 void WebThreadImpl::postTask(Task* task) {
65 FROM_HERE, base::Bind(&blink::WebThread::Task::run, base::Owned(task)));
68 void WebThreadImpl::postDelayedTask(Task* task, long long delay_ms) {
71 base::Bind(&blink::WebThread::Task::run, base::Owned(task)),
104 void WebThreadImplForMessageLoop::postTask(Task* task) {
    [all...]
worker_task_runner.h 23 bool PostTask(int id, const base::Closure& task);
24 int PostTaskToAllThreads(const base::Closure& task);
  /external/chromium_org/gpu/command_buffer/service/
async_pixel_transfer_manager_idle.h 30 struct Task {
31 Task(uint64 transfer_id,
33 const base::Closure& task);
34 ~Task();
36 // This is non-zero if pixel transfer task.
41 base::Closure task; member in struct:gpu::AsyncPixelTransferManagerIdle::Task
52 std::list<Task> tasks;
  /external/chromium_org/media/cast/test/
fake_single_thread_task_runner.h 32 const base::Closure& task,
40 const base::Closure& task,
  /external/chromium_org/mojo/services/html_viewer/
webthread_impl.cc 63 void WebThreadImpl::postTask(Task* task) {
65 FROM_HERE, base::Bind(&blink::WebThread::Task::run, base::Owned(task)));
68 void WebThreadImpl::postDelayedTask(Task* task, long long delay_ms) {
71 base::Bind(&blink::WebThread::Task::run, base::Owned(task)),
103 void WebThreadImplForMessageLoop::postTask(Task* task) {
    [all...]
  /external/chromium_org/storage/browser/quota/
quota_task.h 35 // 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/
Microtask.cpp 36 #include "platform/Task.h"
51 // 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();
69 void Microtask::enqueueMicrotask(PassOwnPtr<WebThread::Task> callback)
77 enqueueMicrotask(adoptPtr(new Task(callback)));
  /external/chromium_org/third_party/WebKit/Source/wtf/
MallocZoneSupport.h 41 RemoteMemoryReader(task_t task, memory_reader_t* reader)
42 : m_task(task)
  /external/chromium_org/third_party/webrtc/base/
taskparent.h 21 class Task;
26 TaskParent(Task *derived_instance, TaskParent *parent);
36 bool IsChildTask(Task *task);
40 void OnStopped(Task *task);
48 void OnChildStopped(Task *child);
49 void AddChild(Task *child);
54 typedef std::set<Task *> ChildSet;
  /external/chromium_org/v8/src/libplatform/
task-queue.cc 5 #include "src/libplatform/task-queue.h"
22 void TaskQueue::Append(Task* task) {
25 task_queue_.push(task);
30 Task* TaskQueue::GetNext() {
35 Task* result = task_queue_.front();
  /external/chromium_org/chrome/browser/sync_file_system/drive_backend/
sync_task_manager.cc 24 explicit SyncTaskAdapter(const SyncTaskManager::Task& task) : task_(task) {}
32 SyncTaskManager::Task task_;
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)),
223 scoped_ptr<SyncTask> task; local
    [all...]
  /cts/suite/audio_quality/lib/include/task/
TaskSequential.h 34 * Queue async task for asynchronous execution (= call complete later)
35 * If the task is already queued, it will not be queued again ,but will just return true.
37 bool queueAsyncTask(TaskAsync* task);
  /cts/suite/audio_quality/test/
TaskCaseCommon.h 25 #include <task/TaskAll.h>
  /external/chromium_org/base/
at_exit.h 45 // Registers the specified task to be called at exit.
46 static void RegisterTask(base::Closure task);
  /external/chromium_org/base/message_loop/
incoming_task_queue.cc 23 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();
  /external/chromium_org/chrome/browser/media_galleries/fileapi/
iapps_finder_impl.h 48 // bouncing to the FILE thread to run |task| and then turning the result into a
49 // device id and posting it to |callback| on the UI thread. If |task| does not
52 const IAppsFinderTask& task,
  /external/chromium_org/chrome/browser/metrics/variations/
variations_request_scheduler_mobile.h 19 // |task} is the closure to call when the scheduler deems ready. |local_state|
21 explicit VariationsRequestSchedulerMobile(const base::Closure& task,
  /external/chromium_org/content/renderer/
scheduler_proxy_task_runner.h 19 blink::WebThread::Task* task)>
33 const base::Closure& task,
36 base::PendingTask pending_task(from_here, task);
49 const base::Closure& task,
59 class TaskAdapter : public blink::WebThread::Task {
  /external/chromium_org/media/cast/
cast_environment.cc 47 const base::Closure& task) {
48 return GetTaskRunner(identifier)->PostTask(from_here, task);
54 const base::Closure& task,
56 return GetTaskRunner(identifier)->PostDelayedTask(from_here, task, delay);
  /external/chromium_org/chrome/browser/chromeos/file_manager/
file_tasks.cc 47 // these are used in default task IDs stored in preferences.
82 // Legacy Drive task extension prefix, used by CrackTaskID.
107 // Returns true if the given task is a handler by built-in apps like Files.app
109 bool IsFallbackFileHandler(const file_tasks::TaskDescriptor& task) {
110 if (task.task_type != file_tasks::TASK_TYPE_FILE_BROWSER_HANDLER &&
111 task.task_type != file_tasks::TASK_TYPE_FILE_HANDLER)
124 if (task.app_id == kBuiltInApps[i])
217 bool ParseTaskID(const std::string& task_id, TaskDescriptor* task) {
218 DCHECK(task);
223 // Parse a legacy task ID that only contain two parts. Drive tasks ar
505 FullTaskDescriptor* task = &tasks->at(i); local
517 FullTaskDescriptor* task = &tasks->at(i); local
    [all...]
  /external/chromium_org/base/debug/
task_annotator.cc 43 // memory allocations to the source function than generically to the task
54 // Before running the task, store the program counter where it was posted
55 // and deliberately alias it to ensure it is on the stack if the task
62 pending_task.task.Run();
69 uint64 TaskAnnotator::GetTaskTraceID(const PendingTask& task) const {
70 return (static_cast<uint64>(task.sequence_num) << 32) |
  /external/chromium_org/base/threading/
worker_pool_win.cc 33 pending_task->task.Run();
66 const base::Closure& task, bool task_is_slow) {
67 PendingTask* pending_task = new PendingTask(from_here, task);
  /external/chromium_org/cc/resources/
rasterizer.cc 59 RasterTaskQueue::Item::Item(RasterTask* task,
61 : task(task), task_sets(task_sets) {
  /external/chromium_org/cc/trees/
blocking_task_runner.cc 35 const base::Closure& task) {
39 return task_runner_->PostTask(from_here, task);
40 captured_tasks_.push_back(task);

Completed in 805 milliseconds

1 2 3 4 5 6 78 91011>>