Android教程網
  1. 首頁
  2. Android 技術
  3. Android 手機
  4. Android 系統教程
  5. Android 游戲
 Android教程網 >> Android技術 >> 關於Android編程 >> Android源碼分析之AsyncTask

Android源碼分析之AsyncTask

編輯:關於Android編程

 AsyncTask相信從事Android開發的同學都不陌生,基本都應該用到了,和以前一樣我們還是先來看看此類的summary。AsyncTask   可以確保更合理、容易的使用UI線程。這個類是設計用來執行一個後台操作然後將結果發布到UI線程,但卻使你不必直接操作Thread   和Handler(其實內部已經為你封裝好了而已)。AsyncTask是圍繞Thread和Handler而設計的一個Helper類,它的目標並不是提供   一個generic的Thread框架。AsyncTask的理想使用情況是針對比較短暫的操作(比如至多幾秒鐘的那種),所以說如果你需要Thread   長時間的運行,那麼強烈建議你使用java.util.concurrent包裡提供的各種API,比如Executor、ThreadPoolExecutor和FutureTask。     接下來我們看看AsyncTask的各個字段,字段比較多:   復制代碼   private static final int CPU_COUNT = Runtime.getRuntime().availableProcessors();     private static final int CORE_POOL_SIZE = CPU_COUNT + 1;     private static final int MAXIMUM_POOL_SIZE = CPU_COUNT * 2 + 1;     private static final int KEEP_ALIVE = 1;       private static final ThreadFactory sThreadFactory = new ThreadFactory() {         private final AtomicInteger mCount = new AtomicInteger(1);           @Override         public Thread newThread(Runnable r) {             return new Thread(r, "AsyncTask #" + mCount.getAndIncrement());         }     };       private static final BlockingQueue<Runnable> sPoolWorkQueue =             new LinkedBlockingQueue<Runnable>(128);       /**      * An {@link Executor} that can be used to execute tasks in parallel.      */     public static final Executor THREAD_POOL_EXECUTOR             = new ThreadPoolExecutor(CORE_POOL_SIZE, MAXIMUM_POOL_SIZE, KEEP_ALIVE,                     TimeUnit.SECONDS, sPoolWorkQueue, sThreadFactory); 復制代碼 這些字段基本都能望文生義,主要是為了創建最下面的ThreadPoolExecutor(有時間的話我會分析下它的源碼),需要留意的   可能就算是這裡CORE_POOL_SIZE的取值,為cpu的數目加1,這樣做可以剛好保持cpu忙碌,最大限度的提高cpu利用率。   ThreadPoolExecutor是一種特殊的Executor,其runnable的執行是在線程池裡並行完成的。     下面我們看看另一種特殊的Executor,串行Executor,代碼如下:   復制代碼   /**      * An {@link Executor} that executes tasks one at a time in serial      * order.  This serialization is global to a particular process.      */     public static final Executor SERIAL_EXECUTOR = new SerialExecutor();     private static class SerialExecutor implements Executor {         final ArrayDeque<Runnable> mTasks = new ArrayDeque<Runnable>();         Runnable mActive;           @Override         public synchronized void execute(final Runnable r) {             mTasks.offer(new Runnable() {                 @Override                 public void run() {                     try {                         r.run();                     } finally {                         scheduleNext();                     }                 }             });             if (mActive == null) {                 scheduleNext();             }         }           protected synchronized void scheduleNext() {             if ((mActive = mTasks.poll()) != null) {                 THREAD_POOL_EXECUTOR.execute(mActive);             }         }     } 復制代碼 這裡的重點是一個Deque實現ArrayDeque,可以看出offer方法往deque尾部添加一個新的Runnable,這個Runnable比較特殊,它做的事情是執行   當前的AsyncTask,最後安排下一個AsyncTask執行(全局的AsyncTask都會在這裡排隊),這樣就實現了AsyncTask的串行執行(執行順序是FIFO)。   這裡要注意的是即使是串行化的執行還是delegate給了同一個(和並行執行每個AsyncTask相比)THREAD_POOL_EXECUTOR。     下面是剩下的一堆字段:   復制代碼     private static final int MESSAGE_POST_RESULT = 0x1;     private static final int MESSAGE_POST_PROGRESS = 0x2;       private static final InternalHandler sHandler = new InternalHandler();       private static volatile Executor sDefaultExecutor = SERIAL_EXECUTOR;     private final WorkerRunnable<Params, Result> mWorker;     private final FutureTask<Result> mFuture;       private volatile Status mStatus = Status.PENDING;       private final AtomicBoolean mCancelled = new AtomicBoolean();     private final AtomicBoolean mTaskInvoked = new AtomicBoolean(); 復制代碼 MESSAGE_xxx之類的是post message用到的what字段;   sHandler是和UI線程相關(所以你應該在UI線程中創建AsyncTask,因為默認其他線程一般沒有與之關聯的Looper)的處理後台線程   post message的Handler,具體代碼稍後分析;   sDefaultExecutor表示默認的Executor,即串行執行的;   mWorker是一個抽象類實現了Callable<Result>接口,還有個Params類型的數組字段mParams;   mFuture表示一個可取消的異步操作,這裡指的就是mWorker;   mStatus表示task執行過程中的狀態,剩下的是2個原子boolean變量,用來做標記使用;     表示task的當前狀態的enum,如下:   復制代碼     /**      * Indicates the current status of the task. Each status will be set only once      * during the lifetime of a task.      */     public enum Status {         /**          * Indicates that the task has not been executed yet.          */         PENDING,         /**          * Indicates that the task is running.          */         RUNNING,         /**          * Indicates that {@link AsyncTask#onPostExecute} has finished.          */         FINISHED,     } 復制代碼   接下來來看一個關鍵部分,ctor代碼如下:   復制代碼     /**      * Creates a new asynchronous task. This constructor must be invoked on the UI thread.      */     public AsyncTask() {         mWorker = new WorkerRunnable<Params, Result>() {             public Result call() throws Exception {                 mTaskInvoked.set(true);                   Process.setThreadPriority(Process.THREAD_PRIORITY_BACKGROUND);                 //noinspection unchecked                 return postResult(doInBackground(mParams));             }         };           mFuture = new FutureTask<Result>(mWorker) {             @Override             protected void done() {                 try {                     postResultIfNotInvoked(get());                 } catch (InterruptedException e) {                     android.util.Log.w(LOG_TAG, e);                 } catch (ExecutionException e) {                     throw new RuntimeException("An error occured while executing doInBackground()",                             e.getCause());                 } catch (CancellationException e) {                     postResultIfNotInvoked(null);                 }             }         };     } 復制代碼 構造器說白了就是分別初始化mWorker和mFuture;mWorker表示可以返回結果的runnable,在其call方法中主要做3件事:   1. 設置task為invoked;   2. 設置線程優先級為BACKGOURND級別;   3. 調用doInBackground(mParams),並將結果發布到UI線程;   mFuture重寫了其protected的done方法,在其內調用get方法來獲取計算結果,get方法可能拋出3種異常,這裡分別處理之;   如果執行正常即沒任何異常的話,則再次將結果post到UI線程如果還沒post過的話;     接下來就來看看將background線程的結果/進度post到UI線程的相關方法:   復制代碼  private void postResultIfNotInvoked(Result result) {         final boolean wasTaskInvoked = mTaskInvoked.get();         if (!wasTaskInvoked) {             postResult(result);         }     }       private Result postResult(Result result) {         @SuppressWarnings("unchecked")         Message message = sHandler.obtainMessage(MESSAGE_POST_RESULT,                 new AsyncTaskResult<Result>(this, result));         message.sendToTarget();         return result;     }       /**      * This method can be invoked from {@link #doInBackground} to      * publish updates on the UI thread while the background computation is      * still running. Each call to this method will trigger the execution of      * {@link #onProgressUpdate} on the UI thread.      *      * {@link #onProgressUpdate} will note be called if the task has been      * canceled.      *      * @param values The progress values to update the UI with.      *      * @see #onProgressUpdate      * @see #doInBackground      */     protected final void publishProgress(Progress... values) {         if (!isCancelled()) {             sHandler.obtainMessage(MESSAGE_POST_PROGRESS,                     new AsyncTaskResult<Progress>(this, values)).sendToTarget();         }     } 復制代碼 前者只在task沒被invoked的時候post,postResult的具體實現是obtain一個Message(將result包裝在Message中),發送給sHandler處理;   publishProgress可以將後台線程的進度周期性的匯報給UI線程,可以用來更新UI顯示,其實現也都是發送Message到sHandler,但是是在任務   沒被取消的前提下。     接下來看幾個客戶端可能需要override的方法,如下:   復制代碼     /**      * Override this method to perform a computation on a background thread. The      * specified parameters are the parameters passed to {@link #execute}      * by the caller of this task.      *      * This method can call {@link #publishProgress} to publish updates      * on the UI thread.      *      * @param params The parameters of the task.      *      * @return A result, defined by the subclass of this task.      *      * @see #onPreExecute()      * @see #onPostExecute      * @see #publishProgress      */     protected abstract Result doInBackground(Params... params);       /**      * Runs on the UI thread before {@link #doInBackground}.      *      * @see #onPostExecute      * @see #doInBackground      */     protected void onPreExecute() {     }       /**      * <p>Runs on the UI thread after {@link #doInBackground}. The      * specified result is the value returned by {@link #doInBackground}.</p>      *      * <p>This method won't be invoked if the task was cancelled.</p>      *      * @param result The result of the operation computed by {@link #doInBackground}.      *      * @see #onPreExecute      * @see #doInBackground      * @see #onCancelled(Object)      */     @SuppressWarnings({"UnusedDeclaration"})     protected void onPostExecute(Result result) {     }       /**      * Runs on the UI thread after {@link #publishProgress} is invoked.      * The specified values are the values passed to {@link #publishProgress}.      *      * @param values The values indicating progress.      *      * @see #publishProgress      * @see #doInBackground      */     @SuppressWarnings({"UnusedDeclaration"})     protected void onProgressUpdate(Progress... values) {     }       /**      * <p>Runs on the UI thread after {@link #cancel(boolean)} is invoked and      * {@link #doInBackground(Object[])} has finished.</p>      *      * <p>The default implementation simply invokes {@link #onCancelled()} and      * ignores the result. If you write your own implementation, do not call      * <code>super.onCancelled(result)</code>.</p>      *      * @param result The result, if any, computed in      *               {@link #doInBackground(Object[])}, can be null      *      * @see #cancel(boolean)      * @see #isCancelled()      */     @SuppressWarnings({"UnusedParameters"})     protected void onCancelled(Result result) {         onCancelled();     }       /**      * <p>Applications should preferably override {@link #onCancelled(Object)}.      * This method is invoked by the default implementation of      * {@link #onCancelled(Object)}.</p>      *      * <p>Runs on the UI thread after {@link #cancel(boolean)} is invoked and      * {@link #doInBackground(Object[])} has finished.</p>      *      * @see #onCancelled(Object)      * @see #cancel(boolean)      * @see #isCancelled()      */     protected void onCancelled() {     }       /**      * Returns <tt>true</tt> if this task was cancelled before it completed      * normally. If you are calling {@link #cancel(boolean)} on the task,      * the value returned by this method should be checked periodically from      * {@link #doInBackground(Object[])} to end the task as soon as possible.      *      * @return <tt>true</tt> if task was cancelled before it completed      *      * @see #cancel(boolean)      */     public final boolean isCancelled() {         return mCancelled.get();     } 復制代碼 這些方法你可以根據自己的需要重寫其中某些,一般doInBackground都會被重寫,因為這是你使用AsyncTask的目的,你的後台操作就發生   在這裡面;其他幾個onXXX之類的方法都發生在UI線程中,算是種callback機制,用來通知UI線程什麼事情發生了。其他要注意的就是仔細閱讀   下方法的doc,每個都有清晰的說明。     下來接著看下public的cancel和get方法,   復制代碼     /**      * <p>Attempts to cancel execution of this task.  This attempt will      * fail if the task has already completed, already been cancelled,      * or could not be cancelled for some other reason. If successful,      * and this task has not started when <tt>cancel</tt> is called,      * this task should never run. If the task has already started,      * then the <tt>mayInterruptIfRunning</tt> parameter determines      * whether the thread executing this task should be interrupted in      * an attempt to stop the task.</p>      *      * <p>Calling this method will result in {@link #onCancelled(Object)} being      * invoked on the UI thread after {@link #doInBackground(Object[])}      * returns. Calling this method guarantees that {@link #onPostExecute(Object)}      * is never invoked. After invoking this method, you should check the      * value returned by {@link #isCancelled()} periodically from      * {@link #doInBackground(Object[])} to finish the task as early as      * possible.</p>      *      * @param mayInterruptIfRunning <tt>true</tt> if the thread executing this      *        task should be interrupted; otherwise, in-progress tasks are allowed      *        to complete.      *      * @return <tt>false</tt> if the task could not be cancelled,      *         typically because it has already completed normally;      *         <tt>true</tt> otherwise      *      * @see #isCancelled()      * @see #onCancelled(Object)      */     public final boolean cancel(boolean mayInterruptIfRunning) {         mCancelled.set(true);         return mFuture.cancel(mayInterruptIfRunning);     }       /**      * Waits if necessary for the computation to complete, and then      * retrieves its result.      *      * @return The computed result.      *      * @throws CancellationException If the computation was cancelled.      * @throws ExecutionException If the computation threw an exception.      * @throws InterruptedException If the current thread was interrupted      *         while waiting.      */     public final Result get() throws InterruptedException, ExecutionException {         return mFuture.get();     }       /**      * Waits if necessary for at most the given time for the computation      * to complete, and then retrieves its result.      *      * @param timeout Time to wait before cancelling the operation.      * @param unit The time unit for the timeout.      *      * @return The computed result.      *      * @throws CancellationException If the computation was cancelled.      * @throws ExecutionException If the computation threw an exception.      * @throws InterruptedException If the current thread was interrupted      *         while waiting.      * @throws TimeoutException If the wait timed out.      */     public final Result get(long timeout, TimeUnit unit) throws InterruptedException,             ExecutionException, TimeoutException {         return mFuture.get(timeout, unit);     } 復制代碼 這些方法沒什麼多說的,都是delegate給了mFuture,主要就是多看看方法的doc。     接下來看看關鍵的executeXXX方法,代碼如下:   復制代碼     /**      * Executes the task with the specified parameters. The task returns      * itself (this) so that the caller can keep a reference to it.      *      * <p>Note: this function schedules the task on a queue for a single background      * thread or pool of threads depending on the platform version.  When first      * introduced, AsyncTasks were executed serially on a single background thread.      * Starting with {@link android.os.Build.VERSION_CODES#DONUT}, this was changed      * to a pool of threads allowing multiple tasks to operate in parallel. Starting      * {@link android.os.Build.VERSION_CODES#HONEYCOMB}, tasks are back to being      * executed on a single thread to avoid common application errors caused      * by parallel execution.  If you truly want parallel execution, you can use      * the {@link #executeOnExecutor} version of this method      * with {@link #THREAD_POOL_EXECUTOR}; however, see commentary there for warnings      * on its use.      *      * <p>This method must be invoked on the UI thread.      *      * @param params The parameters of the task.      *      * @return This instance of AsyncTask.      *      * @throws IllegalStateException If {@link #getStatus()} returns either      *         {@link AsyncTask.Status#RUNNING} or {@link AsyncTask.Status#FINISHED}.      *      * @see #executeOnExecutor(java.util.concurrent.Executor, Object[])      * @see #execute(Runnable)      */     public final AsyncTask<Params, Progress, Result> execute(Params... params) {         return executeOnExecutor(sDefaultExecutor, params);     }       /**      * Executes the task with the specified parameters. The task returns      * itself (this) so that the caller can keep a reference to it.      *      * <p>This method is typically used with {@link #THREAD_POOL_EXECUTOR} to      * allow multiple tasks to run in parallel on a pool of threads managed by      * AsyncTask, however you can also use your own {@link Executor} for custom      * behavior.      *      * <p><em>Warning:</em> Allowing multiple tasks to run in parallel from      * a thread pool is generally <em>not</em> what one wants, because the order      * of their operation is not defined.  For example, if these tasks are used      * to modify any state in common (such as writing a file due to a button click),      * there are no guarantees on the order of the modifications.      * Without careful work it is possible in rare cases for the newer version      * of the data to be over-written by an older one, leading to obscure data      * loss and stability issues.  Such changes are best      * executed in serial; to guarantee such work is serialized regardless of      * platform version you can use this function with {@link #SERIAL_EXECUTOR}.      *      * <p>This method must be invoked on the UI thread.      *      * @param exec The executor to use.  {@link #THREAD_POOL_EXECUTOR} is available as a      *              convenient process-wide thread pool for tasks that are loosely coupled.      * @param params The parameters of the task.      *      * @return This instance of AsyncTask.      *      * @throws IllegalStateException If {@link #getStatus()} returns either      *         {@link AsyncTask.Status#RUNNING} or {@link AsyncTask.Status#FINISHED}.      *      * @see #execute(Object[])      */     public final AsyncTask<Params, Progress, Result> executeOnExecutor(Executor exec,             Params... params) {         if (mStatus != Status.PENDING) {             switch (mStatus) {                 case RUNNING:                     throw new IllegalStateException("Cannot execute task:"                             + " the task is already running.");                 case FINISHED:                     throw new IllegalStateException("Cannot execute task:"                             + " the task has already been executed "                             + "(a task can be executed only once)");             }         }           mStatus = Status.RUNNING;           onPreExecute();           mWorker.mParams = params;         exec.execute(mFuture);           return this;     }       /**      * Convenience version of {@link #execute(Object...)} for use with      * a simple Runnable object. See {@link #execute(Object[])} for more      * information on the order of execution.      *      * @see #execute(Object[])      * @see #executeOnExecutor(java.util.concurrent.Executor, Object[])      */     public static void execute(Runnable runnable) {         sDefaultExecutor.execute(runnable);     } 復制代碼 從上面的代碼可以看出如果你不指定Executor,則默認的串行化Executor會被使用,當然如果你願意也可以提供自己的Executor,   比如AsyncTask.THREAD_POOL_EXECUTOR。executeOnExecutor方法在執行前會做一些狀態檢測,沒執行前應該處於PENDING   狀態,否則就被拋出IllegalStateException,這也就是說同一個AsyncTask只能使用一遍;接下來設置狀態為RUNNING,調用callback   方法onPreExecute,設置mWorker的mParams字段為用戶提供的值,接著在executor中執行mFuture,最後返回this引用。     最後剩下的我們一塊看看,代碼如下:   復制代碼     private void finish(Result result) {         if (isCancelled()) {             onCancelled(result);         } else {             onPostExecute(result);         }         mStatus = Status.FINISHED;     }       private static class InternalHandler extends Handler {         @SuppressWarnings({"unchecked", "RawUseOfParameterizedType"})         @Override         public void handleMessage(Message msg) {             AsyncTaskResult result = (AsyncTaskResult) msg.obj;             switch (msg.what) {                 case MESSAGE_POST_RESULT:                     // There is only one result                     result.mTask.finish(result.mData[0]);                     break;                 case MESSAGE_POST_PROGRESS:                     result.mTask.onProgressUpdate(result.mData);                     break;             }         }     }       private static abstract class WorkerRunnable<Params, Result> implements Callable<Result> {         Params[] mParams;     }       @SuppressWarnings({"RawUseOfParameterizedType"})     private static class AsyncTaskResult<Data> {         final AsyncTask mTask;         final Data[] mData;           AsyncTaskResult(AsyncTask task, Data... data) {             mTask = task;             mData = data;         }     } } 復制代碼 可以看出finish方法是UI線程在收到MESSAGE_POST_RESULT消息的時候調用,如果取消了則調用onCancelled(result),否則調用   onPostExecute(result);最後都設置了task的狀態為FINISHED。同樣的,onProgressUpdate是在收到MESSAGE_POST_PROGRESS   被調用的。最後的2個類都是持有數據的類,WorkerRunnable<Params, Result>是一個Callable<Result>並且持有後台task運行需要用到   的參數列表,後台線程post Message的時候會將結果包裝成一個AsyncTaskResult發送出去。     至此AsyncTask的關鍵代碼都已經分析完畢,我們可以看出AsyncTask實際上是對java.util.concurrent包裡Executor,Callable,FutureTask   以及Handler的一個綜合應用,屬於簡化開發人員流程的一個工具類。
  1. 上一頁:
  2. 下一頁:
熱門文章
閱讀排行版
Copyright © Android教程網 All Rights Reserved