HomeSort by relevance Sort by last modified time
    Searched defs:Task (Results 26 - 50 of 245) sorted by null

12 3 4 5 6 7 8 910

  /external/webrtc/webrtc/base/
task.cc 11 #include "webrtc/base/task.h"
17 int32_t Task::unique_id_seed_ = 0;
19 Task::Task(TaskParent *parent)
37 Task::~Task() {
38 // Is this task being deleted in the correct manner?
43 // If the task is being deleted without being done, it
45 // This happens if a task is deleted outside of TaskRunner.
51 int64_t Task::CurrentTime()
    [all...]
task.h 22 // TASK
26 // Task is a state machine infrastructure. States are pushed forward by
28 // of Task is threefold:
32 // organizing a set of states for each task. When you return from your
39 // task will self-delete sometime afterwards.
42 // too many triggers on one thread. Basically if you want to tell a task
43 // to process something for you, you feed your task some information and
46 // to have a queue in the task.
49 // task gets aborted, all the children tasks are too. The nice thing
50 // about this, for example, is if you have one parent task tha
    [all...]
  /packages/apps/Dialer/java/com/android/dialer/shortcuts/
ShortcutUsageReporter.java 75 EXECUTOR.submit(Task.ID, new Task(context), phoneNumber);
78 private static final class Task extends AsyncTask<String, Void, Void> {
79 private static final String ID = "ShortcutUsageReporter.Task";
83 public Task(Context context) {
  /packages/apps/Dialer/java/com/android/voicemail/impl/scheduling/
Task.java 27 * A task for {@link TaskExecutor} to execute. Since the task is sent through a bundle to the
28 * scheduler, The task must be constructable with the bundle. Specifically, It must have a
30 * Tasks#createIntent(Context, Class)} to create a intent that will construct the Task.
34 public interface Task {
36 * TaskId to indicate it has not be set. If a task does not provide a default TaskId it should be
37 * set before {@link Task#onCreate(Context, Bundle)} returns
43 * Task#onDuplicatedTaskAdded(Task)} will never be called on tasks with this TaskId.
53 * Used to differentiate between types of tasks. If a task with the same TaskId is already in th
    [all...]
  /external/v8/src/heap/
page-parallel-job.h 9 #include "src/cancelable-task.h"
22 // - PerTaskData type - state associated with each task.
73 // The callback takes the index of a task and returns data for that task.
86 Task* main_task = nullptr;
91 Task* task = new Task(heap_, items_, num_items_, start_index, local
93 task_ids[i] = task->id();
96 task, v8::Platform::kShortRunningTask)
    [all...]
store-buffer.h 11 #include "src/cancelable-task.h"
167 class Task : public CancelableTask {
169 Task(Isolate* isolate, StoreBuffer* store_buffer)
171 virtual ~Task() {}
178 DISALLOW_COPY_AND_ASSIGN(Task);
  /art/runtime/
thread_pool.h 37 class Task : public Closure {
43 class SelfDeletingTask : public Task {
101 // Add a new task, the first available started worker will process it. Does not delete the task
103 void AddTask(Thread* self, Task* task) REQUIRES(!task_queue_lock_);
136 // get a task to run, blocks if there are no tasks left
137 virtual Task* GetTask(Thread* self) REQUIRES(!task_queue_lock_);
139 // Try to get a task, returning null if there is none available.
140 Task* TryGetTask(Thread* self) REQUIRES(!task_queue_lock_)
    [all...]
  /device/google/accessory/arduino/USB_Host_Shield/
Max3421e.cpp 289 /* MAX3421 state change task and interrupt handler */
290 byte MAX3421E::Task( void )
Usb.cpp 334 /* USB main task. Performs enumeration/cleanup */
335 void USB::Task( void ) //USB state machine
344 /* modify USB task state if Vbus changed */
363 //Serial.print("USB task state: ");
  /device/linaro/bootloader/edk2/MdeModulePkg/Universal/Disk/DiskIoDxe/
DiskIo.h 53 LIST_ENTRY Link; /// < link to other task
87 DISK_IO2_TASK *Task;
DiskIo.c 355 Destroy the sub task.
370 if (Subtask->Task != NULL) {
371 EfiAcquireLock (&Subtask->Task->SubtasksLock);
374 if (Subtask->Task != NULL) {
375 EfiReleaseLock (&Subtask->Task->SubtasksLock);
410 DISK_IO2_TASK *Task;
416 Task = Subtask->Task;
417 Instance = Task->Instance;
421 ASSERT (Task->Signature == DISK_IO2_TASK_SIGNATURE);
    [all...]
  /device/linaro/bootloader/edk2/MdeModulePkg/Universal/Disk/PartitionDxe/
Partition.c 792 PARTITION_ACCESS_TASK *Task;
794 Task = (PARTITION_ACCESS_TASK *) Context;
798 Task->BlockIo2Token->TransactionStatus = Task->DiskIo2Token.TransactionStatus;
799 gBS->SignalEvent (Task->BlockIo2Token->Event);
801 FreePool (Task);
817 PARTITION_ACCESS_TASK *Task;
819 Task = AllocatePool (sizeof (*Task));
820 if (Task == NULL) {
    [all...]
  /external/smali/dexlib2/src/main/java/org/jf/dexlib2/builder/
MutableMethodImplementation.java 82 List<Task> switchPayloadTasks = Lists.newArrayList();
88 switchPayloadTasks.add(new Task() {
101 for (Task switchPayloadTask: switchPayloadTasks) {
126 private interface Task {
    [all...]
  /external/toolchain-utils/bestflags/
task.py 8 The Task class is used by different modules. Each module fills in the
9 corresponding information into a Task instance. Class Task contains the bit set
11 the image and the checksum field of a Task. The executor module will put the
46 class Task(object):
62 """Set up the build and test command for the task and the log directory.
70 this task.
72 task.
76 Task.BUILD_COMMAND = build_command
77 Task.TEST_COMMAND = test_comman
    [all...]
  /frameworks/base/packages/MtpDocumentsProvider/src/com/android/mtp/
PipeManager.java 46 final Task task = new ImportFileTask(model, identifier); local
47 mExecutor.execute(task);
48 return task.getReadingFileDescriptor();
52 final Task task = new GetThumbnailTask(model, identifier); local
53 mExecutor.execute(task);
54 return task.getReadingFileDescriptor();
57 private static abstract class Task implements Runnable {
62 Task(MtpManager manager, Identifier identifier) throws IOException
    [all...]
  /frameworks/native/services/vr/performanced/
task.h 20 // Task provides access to task-related information from the procfs
22 class Task {
24 explicit Task(pid_t task_id);
76 Task(const Task&) = delete;
77 void operator=(const Task&) = delete;
  /packages/apps/DocumentsUI/tests/common/com/android/documentsui/testing/
TestTimer.java 33 private final LinkedList<Task> mTaskList = new LinkedList<>();
46 Task task = mTaskList.getFirst(); local
47 if (!task.isCancelled()) {
48 task.run();
60 throw new IllegalStateException("There is no scheduled task!");
73 Iterator<Task> iter = mTaskList.iterator();
75 Task task = iter.next(); local
76 if (task.isCancelled())
    [all...]
  /packages/apps/Settings/src/com/android/settings/password/
SaveChosenLockWorkerBase.java 88 new Task().execute();
110 private class Task extends AsyncTask<Void, Void, Intent> {
  /external/libmojo/mojo/public/cpp/bindings/lib/
multiplex_router.cc 230 // The task runner on which |client_|'s methods can be called.
253 struct MultiplexRouter::Task {
256 static std::unique_ptr<Task> CreateMessageTask(Message* message) {
257 Task* task = new Task(MESSAGE); local
258 task->message.reset(new Message);
259 message->MoveTo(task->message.get());
260 return base::WrapUnique(task);
262 static std::unique_ptr<Task> CreateNotifyErrorTask
264 Task* task = new Task(NOTIFY_ERROR); local
498 Task* task = tasks_.back().get(); local
    [all...]
  /external/gemmlowp/internal/
multi_thread_gemm.h 206 struct Task {
207 Task() : local_allocator(nullptr) {}
208 virtual ~Task() {}
306 void StartWork(Task* task) {
308 task->local_allocator = &local_allocator_;
309 task_ = task;
321 // The task to be worked on.
322 Task* task_;
359 void Execute(const std::vector<Task*>& tasks)
371 Task* task = tasks.back(); local
    [all...]
  /device/google/contexthub/firmware/os/inc/
seos_priv.h 24 #define for_each_task(listHead, task) for (task = osTaskByIdx((listHead)->next); task; task = osTaskByIdx(task->list.next))
50 struct Task {
63 /* task pointer will not change throughout task lifetime,
64 * however same task pointer may be reused for a new task; to eliminate the ambiguity
    [all...]
  /device/linaro/bootloader/edk2/MdeModulePkg/Bus/Ata/AtaBusDxe/
AtaPassThruExecute.c 566 @param[in, out] Task Pointer to task to be freed.
572 IN OUT ATA_BUS_ASYN_SUB_TASK *Task
575 if (Task->Packet.Asb != NULL) {
576 FreeAlignedBuffer (Task->Packet.Asb, sizeof (EFI_ATA_STATUS_BLOCK));
578 if (Task->Packet.Acb != NULL) {
579 FreePool (Task->Packet.Acb);
582 FreePool (Task);
656 ATA_BUS_ASYN_SUB_TASK *Task;
662 Task = (ATA_BUS_ASYN_SUB_TASK *) Context;
    [all...]
  /external/autotest/site_utils/suite_scheduler/
task.py 135 class Task(object):
139 Task. Each instance has enough info to schedule itself
149 """Create a Task from a section of a config file.
173 @param section: the section to parse into a Task.
175 @return keyword, Task object pair. One or both will be None on error.
289 Task.CheckBranchSpecs(specs)
335 # TODO(xixuan): Raise MalformedConfigEntry when a CrOS task
343 return keyword, Task(section, suite, specs, pool, num, boards,
406 t = Task('Name', 'suite', ['factory', '>=R18'])
413 t = Task('Name', 'suite', ['factory', '==R18']
    [all...]
  /external/eigen/unsupported/Eigen/CXX11/src/ThreadPool/
NonBlockingThreadPool.h 19 typedef typename Environment::Task Task;
20 typedef RunQueue<Task, 1024> Queue;
75 Task t = env_.CreateTask(std::move(fn));
143 Task t = q->PopFront();
173 Task Steal() {
180 Task t = queues_[victim]->PopBack();
189 return Task();
193 // time to exit (returns false). Can optionally return a task to execute in t
195 bool WaitForWork(EventCount::Waiter* waiter, Task* t)
    [all...]
  /system/bt/vendor_libs/test_vendor_lib/src/
async_manager.cc 57 // after a Task has been scheduled and access to internal state is synchronized
58 // using a single internal mutex. When the first task is scheduled a thread
60 // when the next task should be carried out and then the thread performs a
62 // time out or a notify on the cond var, the former means a task is due
64 // state, like a task has been scheduled/canceled or the flag to stop has
65 // been set. Setting and querying the stop flag or modifying the task queue
277 // Async task manager implementation
282 return scheduleTask(std::make_shared<Task>(
289 return scheduleTask(std::make_shared<Task>(
294 // remove task from queue (and task id asociation) while holding loc
    [all...]

Completed in 753 milliseconds

12 3 4 5 6 7 8 910