Searched defs:task (Results 1 - 25 of 42) sorted by relevance

12

/frameworks/support/v4/honeycomb/android/support/v4/os/
H A DAsyncTaskCompatHoneycomb.java27 AsyncTask<Params, Progress, Result> task,
29 task.executeOnExecutor(AsyncTask.THREAD_POOL_EXECUTOR, params);
26 executeParallel( AsyncTask<Params, Progress, Result> task, Params... params) argument
/frameworks/support/v4/java/android/support/v4/os/
H A DAsyncTaskCompat.java29 * Executes the task with the specified parameters, allowing multiple tasks to run in parallel
32 * @param task The {@link android.os.AsyncTask} to execute.
33 * @param params The parameters of the task.
37 AsyncTask<Params, Progress, Result> task,
39 if (task == null) {
40 throw new IllegalArgumentException("task can not be null");
45 AsyncTaskCompatHoneycomb.executeParallel(task, params);
48 task.execute(params);
51 return task;
36 executeParallel( AsyncTask<Params, Progress, Result> task, Params... params) argument
/frameworks/base/libs/hwui/thread/
H A DTaskProcessor.h36 virtual void process(const sp<TaskBase>& task) = 0;
45 bool add(const sp<Task<T> >& task);
47 virtual void onProcess(const sp<Task<T> >& task) = 0;
50 virtual void process(const sp<TaskBase>& task) { argument
51 sp<Task<T> > realTask = static_cast<Task<T>* >(task.get());
53 // sp<Task<T> > realTask = static_cast<sp<Task<T> > >(task);
61 bool TaskProcessor<T>::add(const sp<Task<T> >& task) { argument
64 return mManager->addTask(task, self);
H A DTaskManager.h44 * Returns true if this task manager can run tasks,
61 bool addTask(const sp<Task<T> >& task, const sp<TaskProcessor<T> >& processor) { argument
62 return addTaskBase(sp<TaskBase>(task), sp<TaskProcessorBase>(processor));
65 bool addTaskBase(const sp<TaskBase>& task, const sp<TaskProcessorBase>& processor);
70 TaskWrapper(const sp<TaskBase>& task, const sp<TaskProcessorBase>& processor): argument
71 mTask(task), mProcessor(processor) {
82 bool addTask(TaskWrapper task);
95 // task is available in the list
H A DTaskManager.cpp62 bool TaskManager::addTaskBase(const sp<TaskBase>& task, const sp<TaskProcessorBase>& processor) { argument
64 TaskWrapper wrapper(task, processor);
102 const TaskWrapper& task = tasks.itemAt(i); local
103 task.mProcessor->process(task.mTask);
109 bool TaskManager::WorkerThread::addTask(TaskWrapper task) { argument
115 ssize_t index = mTasks.add(task);
/frameworks/base/tools/aidl/
H A Doptions.h18 int task; member in struct:Options
/frameworks/base/packages/DocumentsUI/src/com/android/documentsui/
H A DProviderExecutor.java73 * Execute the given task. If given task is not {@link Preemptable}, it will
76 public <P> void execute(AsyncTask<P, ?, ?> task, P... params) { argument
77 if (task instanceof Preemptable) {
79 mPreemptable.add(new WeakReference<Preemptable>((Preemptable) task));
81 task.executeOnExecutor(mNonPreemptingExecutor, params);
83 task.executeOnExecutor(this, params);
/frameworks/base/core/java/android/hardware/camera2/utils/
H A DTaskDrainer.java31 * <p>The initial state is to allow all tasks to be started and finished. A task may only be started
32 * once, after which it must be finished before starting again. Likewise, finishing a task
69 * Create a new task drainer; {@code onDrained} callbacks will be posted to the listener
82 * Create a new task drainer; {@code onDrained} callbacks will be posted to the listener
97 * Mark an asynchronous task as having started.
99 * <p>A task cannot be started more than once without first having finished. Once
102 * @param task a key to identify a task
108 * If attempting to start a task which is already started (and not finished),
109 * or if attempting to start a task afte
111 taskStarted(T task) argument
142 taskFinished(T task) argument
[all...]
/frameworks/base/libs/hwui/renderthread/
H A DRenderTask.h61 // Takes ownership of task, caller owns lock and signal
62 SignalingRenderTask(RenderTask* task, Mutex* lock, Condition* signal) argument
63 : mTask(task), mLock(lock), mSignal(signal) {}
H A DRenderThread.cpp63 void TaskQueue::queue(RenderTask* task) { argument
65 // to have the same task queued twice
66 LOG_ALWAYS_FATAL_IF(task->mNext || mTail == task, "Task is already in the queue!");
69 if (mTail->mRunAt <= task->mRunAt) {
70 mTail->mNext = task;
71 mTail = task;
76 while (next && next->mRunAt <= task->mRunAt) {
81 task->mNext = mHead;
82 mHead = task;
97 queueAtFront(RenderTask* task) argument
106 remove(RenderTask* task) argument
300 queue(RenderTask* task) argument
309 queueAtFront(RenderTask* task) argument
315 queueAt(RenderTask* task, nsecs_t runAtNs) argument
320 remove(RenderTask* task) argument
[all...]
H A DCanvasContext.cpp358 void CanvasContext::runWithGlContext(RenderTask* task) { argument
360 task->run();
H A DRenderProxy.cpp52 MethodInvokeRenderTask* task = new MethodInvokeRenderTask((RunnableMethod) Bridge_ ## method); \
53 ARGS(method) *args = (ARGS(method) *) task->payload()
69 mContext = (CanvasContext*) postAndWait(task);
90 postAndWait(task);
103 post(task);
115 post(task);
132 return (bool) postAndWait(task);
143 return (bool) postAndWait(task);
155 postAndWait(task);
166 return (bool) postAndWait(task);
243 CREATE_BRIDGE2(runWithGlContext, CanvasContext* context, RenderTask* task) argument
413 post(RenderTask* task) argument
417 postAndWait(MethodInvokeRenderTask* task) argument
427 staticPostAndWait(MethodInvokeRenderTask* task) argument
[all...]
/frameworks/opt/bitmap/src/com/android/bitmap/
H A DContiguousFIFOAggregator.java29 * An implementation of a task aggregator that executes tasks in the order that they are expected
32 * The task will be scheduled to run when its corresponding key becomes the first expected key
35 * If on {@link #execute(Object, Runnable)} the key is not expected, the task will be executed
42 * <li>Execute task <b>2</b> for key <b>B</b>. The first expected key is <b>A</b>,
43 * which has no task associated with it, so we store task <b>2</b>. </li>
44 * <li>Execute task <b>4</b> for key <b>Z</b>. We store task <b>4</b>. </li>
45 * <li>Execute task <b>1</b> for key <b>A</b>. We run task <
165 execute(final T key, final Runnable task) argument
301 Runnable task; field in class:ContiguousFIFOAggregator.Value
303 Value(final Callback<T> callback, final Runnable task) argument
[all...]
/frameworks/support/v4/java/android/support/v4/content/
H A DAsyncTaskLoader.java119 * Attempt to cancel the current load task. See {@link android.os.AsyncTask#cancel(boolean)}
129 * @return Returns <tt>false</tt> if the task could not be cancelled,
138 // There was a pending task already waiting for a previous
141 "cancelLoad: still waiting for cancelled task; dropping next");
149 // There is a task, but it is waiting for the time it should
151 if (DEBUG) Log.v(TAG, "cancelLoad: task is waiting, dropping it");
170 * Called if the task was canceled before it was completed. Gives the class a chance
199 void dispatchOnCancelled(LoadTask task, D data) { argument
201 if (mCancellingTask == task) {
202 if (DEBUG) Log.v(TAG, "Cancelled task i
210 dispatchOnLoadComplete(LoadTask task, D data) argument
[all...]
H A DModernAsyncTask.java86 * Indicates the current status of the task. Each status will be set only once
87 * during the lifetime of a task.
91 * Indicates that the task has not been executed yet.
95 * Indicates that the task is running.
115 * Creates a new asynchronous task. This constructor must be invoked on the UI thread.
164 * Returns the current status of this task.
175 * by the caller of this task.
180 * @param params The parameters of the task.
182 * @return A result, defined by the subclass of this task.
203 * <p>This method won't be invoked if the task wa
492 AsyncTaskResult(ModernAsyncTask task, Data... data) argument
[all...]
/frameworks/base/core/java/android/content/
H A DAsyncTaskLoader.java60 // Set to true to indicate that the task has been posted to a handler for
78 // reflect the fact that the task was being canceled.
109 /* Runs on the UI thread, when the waiting task is posted to a handler.
110 * This method is only executed when task execution was deferred (waiting was true). */
117 /* Used for testing purposes to wait for the task to complete. */
174 // There was a pending task already waiting for a previous
177 "cancelLoad: still waiting for cancelled task; dropping next");
185 // There is a task, but it is waiting for the time it should
187 if (DEBUG) Log.v(TAG, "cancelLoad: task is waiting, dropping it");
207 * Called if the task wa
239 dispatchOnCancelled(LoadTask task, D data) argument
252 dispatchOnLoadComplete(LoadTask task, D data) argument
[all...]
/frameworks/base/packages/SystemUI/src/com/android/systemui/recents/views/
H A DTaskStackViewLayoutAlgorithm.java80 /** Computes the stack and task rects */
92 // Compute the task rect
135 // Update the task offsets
140 Task task = tasks.get(i);
141 mTaskProgressMap.put(task.key, pAtFrontMostCardTop);
145 float pPeek = task.group.isFrontMostTask(task) ?
154 // Center the top most task, since that will be focused first
171 // Walk backwards in the task stack and count the number of tasks and visible thumbnails
178 Task task
214 getStackTransform(Task task, float stackScroll, TaskViewTransform transformOut, TaskViewTransform prevTransform) argument
[all...]
H A DRecentsView.java153 /** Launches the focused task from the first stack if possible */
162 // Iterate the stack views and try and find the focused task
166 Task task = tv.getTask();
168 onTaskViewClicked(stackView, tv, stack, task, false);
177 /** Launches the task that Recents was launched from, if possible */
188 // Find the launch task in the stack
193 Task task = tasks.get(j);
194 TaskView tv = stackView.getChildViewForTask(task);
195 onTaskViewClicked(stackView, tv, stack, task, false);
205 /** Requests all task stack
404 onTaskViewClicked(final TaskStackView stackView, final TaskView tv, final TaskStack stack, final Task task, final boolean lockToTask) argument
[all...]
/frameworks/base/services/core/java/com/android/server/wm/
H A DTaskStack.java169 * @param task The task to add.
172 void addTask(Task task, boolean toTop) { argument
178 if (!mService.isCurrentProfileLocked(task.mUserId)) {
179 // Place the task below all current user tasks.
185 // Put it above first non-current user task.
189 if (DEBUG_TASK_MOVEMENT) Slog.d(TAG, "addTask: task=" + task + " toTop=" + toTop
191 mTasks.add(stackNdx, task);
193 task
198 moveTaskToTop(Task task) argument
205 moveTaskToBottom(Task task) argument
216 removeTask(Task task) argument
[all...]
/frameworks/base/tests/ActivityTests/src/com/google/android/test/activity/
H A DActivityTestMain.java102 final ActivityManager.RecentTaskInfo task,
116 if (task.id >= 0 && thumbs != null) {
117 mAm.moveTaskToFront(task.id, ActivityManager.MOVE_TASK_WITH_HOME);
120 startActivity(task.baseIntent);
122 Log.w("foo", "Unable to start task: " + e);
131 if (task.id >= 0 && thumbs != null) {
132 mAm.removeTask(task.id);
378 ActivityManager.AppTask task = findDocTask();
379 if (task == null) {
386 task
101 addThumbnail(LinearLayout container, Bitmap bm, final ActivityManager.RecentTaskInfo task, final ActivityManager.TaskThumbnail thumbs) argument
[all...]
/frameworks/base/core/java/android/os/
H A DAsyncTask.java46 * <p>An asynchronous task is defined by a computation that runs on a background thread and
47 * whose result is published on the UI thread. An asynchronous task is defined by 3 generic
89 * <p>Once created, a task is executed very simply:</p>
95 * <p>The three types used by an asynchronous task are the following:</p>
97 * <li><code>Params</code>, the type of the parameters sent to the task upon
104 * <p>Not all types are always used by an asynchronous task. To mark a type as unused,
111 * <p>When an asynchronous task is executed, the task goes through 4 steps:</p>
113 * <li>{@link #onPreExecute()}, invoked on the UI thread before the task
114 * is executed. This step is normally used to setup the task, fo
671 AsyncTaskResult(AsyncTask task, Data... data) argument
[all...]
H A DHandler.java422 * Runs the specified task synchronously.
433 * must synchronously await completion of a task that must run on the
752 public BlockingRunnable(Runnable task) { argument
753 mTask = task;
/frameworks/base/libs/hwui/
H A DPathCache.cpp211 // If there is a pending task we must wait for it to return
213 const sp<Task<SkBitmap*> >& task = texture->task(); local
214 if (task != NULL) {
215 SkBitmap* bitmap = task->getResult();
218 // If there is a pending task, the path was not added
336 void PathCache::PathProcessor::onProcess(const sp<Task<SkBitmap*> >& task) { argument
337 PathTask* t = static_cast<PathTask*>(task.get());
432 const sp<Task<SkBitmap*> >& task = texture->task(); local
481 sp<PathTask> task = new PathTask(path, paint, texture); local
[all...]
H A DPathCache.h82 sp<Task<SkBitmap*> > task() const { function in struct:android::uirenderer::PathTexture
86 void setTask(const sp<Task<SkBitmap*> >& task) { argument
87 mTask = task;
282 // copied, since input path not refcounted / guaranteed to survive for duration of task
296 virtual void onProcess(const sp<Task<SkBitmap*> >& task);
/frameworks/support/v4/java/android/support/v4/app/
H A DNotificationManagerCompat.java264 * Push a notification task for distribution to notification side channels.
266 private void pushSideChannelQueue(Task task) { argument
272 sSideChannelManager.queueTask(task);
302 * Queue a new task to be sent to all listeners. This function can be called
305 public void queueTask(Task task) { argument
306 mHandler.obtainMessage(MSG_QUEUE_TASK, task).sendToTarget();
329 private void handleQueueTask(Task task) { argument
332 record.taskQueue.add(task);
485 * to flush the task queue, and if an error is encountered, schedule a retry.
500 // Attempt to flush all items in the task queu
[all...]

Completed in 7472 milliseconds

12