Netty NioEventLoop 啟動過程原始碼分析
啟動
在之前分析 的文章中,提到過下面這段程式碼,先前只講了 channel.bind() 繫結邏輯,跳過了execute() 介面,現在我們以這個為例,開始分析NioEventLoop的execute()介面,主要邏輯如下:
-
新增任務佇列
-
繫結當前執行緒到EventLoop上
-
呼叫EventLoop的run()方法
private static void doBind0( final ChannelFuture regFuture, final Channel channel, final SocketAddress localAddress, final ChannelPromise promise) { // 透過eventLoop來執行channel繫結的Task channel.eventLoop().execute(new Runnable() { @Override public void run() { if (regFuture.isSuccess()) { // channel繫結 channel.bind(localAddress, promise).addListener(ChannelFutureListener.CLOSE_ON_FAILURE); } else { promise.setFailure(regFuture.cause()); } } }); }
往下追蹤到 SingleThreadEventExecutor 中 execute 介面,如下:
@Overridepublic void execute(Runnable task) { if (task == null) { throw new NullPointerException("task"); } // 判斷當前執行時執行緒是否與EventLoop中繫結的執行緒一致 // 這裡還未繫結Thread,所以先返回false boolean inEventLoop = inEventLoop(); // 將任務新增任務佇列,也就是我們前面講EventLoop建立時候提到的 MpscQueue. addTask(task); if (!inEventLoop) { // 啟動執行緒 startThread(); if (isShutdown() && removeTask(task)) { reject(); } } if (!addTaskWakesUp && wakesUpForTask(task)) { wakeup(inEventLoop); } }
啟動執行緒介面:
private void startThread() { // 狀態比較,最開始時state = 1 ,為true if (state == ST_NOT_STARTED) { // cs操作後,state狀態設定為 2 if (STATE_UPDATER.compareAndSet(this, ST_NOT_STARTED, ST_STARTED)) { try { // 啟動介面 doStartThread(); } catch (Throwable cause) { STATE_UPDATER.set(this, ST_NOT_STARTED); PlatformDependent.throwException(cause); } } } }// 執行執行緒啟動方法private void doStartThread() { // 斷言判斷 SingleThreadEventExecutor 還未繫結 Thread assert thread == null; // executor 執行任務 executor.execute(new Runnable() { @Override public void run() { // 將 SingleThreadEventExecutor(在我們的案例中就是NioEventLoop) 與 當前執行緒進行繫結 thread = Thread.currentThread(); if (interrupted) { thread.interrupt(); } // 設定狀態為 false boolean success = false; // 更新最近一次任務的執行時間 updateLastExecutionTime(); try { // 往下呼叫 NioEventLoop 的 run 方法,執行 SingleThreadEventExecutor.this.run(); success = true; } catch (Throwable t) { logger.warn("Unexpected exception from an event executor: ", t); } finally { ... } } }); }
執行
往下呼叫到 NioEventLoop 中的 run 方法,透過無限for迴圈,主要做以下三件事情:
-
輪循I/O事件:select(wakenUp.getAndSet(false))
-
處理I/O事件:processSelectedKeys
-
執行Task任務:runAllTasks
@Overrideprotected void run() { for (;;) { try { switch (selectStrategy.calculateStrategy(selectNowSupplier, hasTasks())) { case SelectStrategy.CONTINUE: continue; case SelectStrategy.SELECT: // 輪訓檢測I/O事件 // wakenUp為了標記selector是否是喚醒狀態,每次select操作,都設定為false,也就是未喚醒狀態。 select(wakenUp.getAndSet(false)); // 'wakenUp.compareAndSet(false, true)' 總是在呼叫 'selector.wakeup()' 之前進行評估,以減少喚醒的開銷 // (Selector.wakeup() 是非常耗效能的操作.) // 但是,這種方法存在競爭條件。當「wakeup」太早設定為true時觸發競爭條件 // 在下面兩種情況下,「wakenUp」會過早設定為true: // 1)Selector 在 'wakenUp.set(false)' 與 'selector.select(...)' 之間被喚醒。(BAD) // 2)Selector 在 'selector.select(...)' 與 'if (wakenUp.get()) { ... }' 之間被喚醒。(OK) // 在第一種情況下,'wakenUp'設定為true,後面的'selector.select(...)'將立即喚醒。 直到'wakenUp'在下一輪中再次設定為false,'wakenUp.compareAndSet(false,true)'將失敗,因此任何喚醒選擇器的嘗試也將失敗,從而導致以下'selector.select(。 ..)'呼籲阻止不必要的。 // 要解決這個問題,如果在selector.select(...)操作之後wakenUp立即為true,我們會再次喚醒selector。 它是低效率的,因為它喚醒了第一種情況(BAD - 需要喚醒)和第二種情況(OK - 不需要喚醒)的選擇器。 if (wakenUp.get()) { selector.wakeup(); } // fall through default: } cancelledKeys = 0; needsToSelectAgain = false; // ioRatio 表示處理I/O事件與執行具體任務事件之間所耗時間的比值。 // ioRatio 預設為50 final int ioRatio = this.ioRatio; if (ioRatio == 100) { try { // 處理I/O事件 processSelectedKeys(); } finally { // 處理任務佇列 runAllTasks(); } } else { // 處理IO事件的開始時間 final long ioStartTime = System.nanoTime(); try { // 處理I/O事件 processSelectedKeys(); } finally { // 記錄io所耗時間 final long ioTime = System.nanoTime() - ioStartTime; // 處理任務佇列,設定最大的超時時間 runAllTasks(ioTime * (100 - ioRatio) / ioRatio); } } } catch (Throwable t) { handleLoopException(t); } // Always handle shutdown even if the loop processing threw an exception. try { if (isShuttingDown()) { closeAll(); if (confirmShutdown()) { return; } } } catch (Throwable t) { handleLoopException(t); } } }
輪循檢測I/O事件
private void select(boolean oldWakenUp) throws IOException { Selector selector = this.selector; try { // select操作計數 int selectCnt = 0; // 記錄當前系統時間 long currentTimeNanos = System.nanoTime(); // delayNanos方法用於計算定時任務佇列,最近一個任務的截止時間 // selectDeadLineNanos 表示當前select操作所不能超過的最大截止時間 long selectDeadLineNanos = currentTimeNanos + delayNanos(currentTimeNanos); for (;;) { // 計算超時時間,判斷是否超時 long timeoutMillis = (selectDeadLineNanos - currentTimeNanos + 500000L) / 1000000L; // 如果 timeoutMillis <= 0, 表示超時,進行一個非阻塞的 select 操作。設定 selectCnt 為 1. 並終止本次迴圈。 if (timeoutMillis <= 0) { if (selectCnt == 0) { selector.selectNow(); selectCnt = 1; } break; } // 當wakenUp為ture時,恰好有task被提交,這個task將無法獲得呼叫的機會 // Selector#wakeup. 因此,在執行select操作之前,需要再次檢查任務佇列 // 如果不這麼做,這個Task將一直掛起,直到select操作超時 // 如果 pipeline 中存在 IdleStateHandler ,那麼Task將一直掛起直到 空閒超時。 if (hasTasks() && wakenUp.compareAndSet(false, true)) { // 呼叫非阻塞方法 selector.selectNow(); selectCnt = 1; break; } // 如果當前任務佇列為空,並且超時時間未到,則進行一個阻塞式的selector操作。timeoutMillis 為最大的select時間 int selectedKeys = selector.select(timeoutMillis); // 操作計數 +1 selectCnt ++; // 存在以下情況,本次selector則終止 if (selectedKeys != 0 || oldWakenUp || wakenUp.get() || hasTasks() || hasScheduledTasks()) { // - 輪訓到了事件(Selected something,) // - 被使用者喚醒(waken up by user,) // - 已有任務佇列(the task queue has a pending task.) // - 已有定時任務(a scheduled task is ready for processing) break; } if (Thread.interrupted()) { // Thread was interrupted so reset selected keys and break so we not run into a busy loop. // As this is most likely a bug in the handler of the user or it's client library we will // also log it. // // See if (logger.isDebugEnabled()) { logger.debug("Selector.select() returned prematurely because " + "Thread.currentThread().interrupt() was called. Use " + "NioEventLoop.shutdownGracefully() to shutdown the NioEventLoop."); } selectCnt = 1; break; } // 記錄當前時間 long time = System.nanoTime(); // 如果time > currentTimeNanos + timeoutMillis(超時時間),則表明已經執行過一次select操作 if (time - TimeUnit.MILLISECONDS.toNanos(timeoutMillis) >= currentTimeNanos) { // timeoutMillis elapsed without anything selected. selectCnt = 1; } // 如果 time <= currentTimeNanos + timeoutMillis,表示觸發了空輪訓 // 如果空輪訓的次數超過 SELECTOR_AUTO_REBUILD_THRESHOLD (512),則重建一個新的selctor,避免空輪訓 else if (SELECTOR_AUTO_REBUILD_THRESHOLD > 0 && selectCnt >= SELECTOR_AUTO_REBUILD_THRESHOLD) { // The selector returned prematurely many times in a row. // Rebuild the selector to work around the problem. logger.warn( "Selector.select() returned prematurely {} times in a row; rebuilding Selector {}.", selectCnt, selector); // 重建建立一個新的selector rebuildSelector(); selector = this.selector; // Select again to populate selectedKeys. // 對重建後的selector進行一次非阻塞呼叫,用於獲取最新的selectedKeys selector.selectNow(); // 設定select計數 selectCnt = 1; break; } currentTimeNanos = time; } if (selectCnt > MIN_PREMATURE_SELECTOR_RETURNS) { if (logger.isDebugEnabled()) { logger.debug("Selector.select() returned prematurely {} times in a row for Selector {}.", selectCnt - 1, selector); } } } catch (CancelledKeyException e) { if (logger.isDebugEnabled()) { logger.debug(CancelledKeyException.class.getSimpleName() + " raised by a Selector {} - JDK bug?", selector, e); } // Harmless exception - log anyway } }
重新建立一個新的Selector
該方法的主要邏輯就是:
-
建立一個新的selector
-
將老的selector上的 selectKey註冊到新的 selector 上
public void rebuildSelector() { if (!inEventLoop()) { execute(new Runnable() { @Override public void run() { rebuildSelector0(); } }); return; } rebuildSelector0(); }// 重新建立selectorprivate void rebuildSelector0() { // 暫存老的selector final Selector oldSelector = selector; final SelectorTuple newSelectorTuple; if (oldSelector == null) { return; } try { // 建立一個新的 SelectorTuple // openSelector()在之前分析過了 newSelectorTuple = openSelector(); } catch (Exception e) { logger.warn("Failed to create a new Selector.", e); return; } // Register all channels to the new Selector. // 記錄select上註冊的channel數量 int nChannels = 0; // 遍歷老的 selector 上的 SelectionKey for (SelectionKey key: oldSelector.keys()) { // 獲取 attachment,這裡的attachment就是我們前面在講 Netty Channel註冊時,select會將channel賦值到 attachment 變數上。 // 獲取老的selector上註冊的channel Object a = key.attachment(); try { if (!key.isValid() || key.channel().keyFor(newSelectorTuple.unwrappedSelector) != null) { continue; } // 獲取興趣集 int interestOps = key.interestOps(); // 取消 SelectionKey key.cancel(); // 將老的興趣集重新註冊到前面新建立的selector上 SelectionKey newKey = key.channel().register(newSelectorTuple.unwrappedSelector, interestOps, a); if (a instanceof AbstractNioChannel) { // Update SelectionKey ((AbstractNioChannel) a).selectionKey = newKey; } // nChannels計數 + 1 nChannels ++; } catch (Exception e) { logger.warn("Failed to re-register a Channel to the new Selector.", e); if (a instanceof AbstractNioChannel) { AbstractNioChannel ch = (AbstractNioChannel) a; ch.unsafe().close(ch.unsafe().voidPromise()); } else { @SuppressWarnings("unchecked") NioTask<SelectableChannel> task = (NioTask<SelectableChannel>) a; invokeChannelUnregistered(task, key, e); } } } // 設定新的 selector selector = newSelectorTuple.selector; // 設定新的 unwrappedSelector unwrappedSelector = newSelectorTuple.unwrappedSelector; try { // time to close the old selector as everything else is registered to the new one // 關閉老的seleclor oldSelector.close(); } catch (Throwable t) { if (logger.isWarnEnabled()) { logger.warn("Failed to close the old Selector.", t); } } if (logger.isInfoEnabled()) { logger.info("Migrated " + nChannels + " channel(s) to the new Selector."); } }
處理I/O事件
private void processSelectedKeysOptimized() { for (int i = 0; i < selectedKeys.size; ++i) { final SelectionKey k = selectedKeys.keys[i]; // null out entry in the array to allow to have it GC'ed once the Channel close // See // 設定為null,有利於GC回收 selectedKeys.keys[i] = null; // 獲取 SelectionKey 中的 attachment, 我們這裡就是 NioChannel final Object a = k.attachment(); if (a instanceof AbstractNioChannel) { // 處理 SelectedKey processSelectedKey(k, (AbstractNioChannel) a); } else { @SuppressWarnings("unchecked") NioTask<SelectableChannel> task = (NioTask<SelectableChannel>) a; processSelectedKey(k, task); } if (needsToSelectAgain) { // null out entries in the array to allow to have it GC'ed once the Channel close // See selectedKeys.reset(i + 1); selectAgain(); i = -1; } } }// 處理 SelectedKeyprivate void processSelectedKey(SelectionKey k, AbstractNioChannel ch) { // 獲取Netty Channel中的 NioUnsafe 物件,用於後面的IO操作 final AbstractNioChannel.NioUnsafe unsafe = ch.unsafe(); // 判斷 SelectedKey 的有效性,如果無效,則直接返回並關閉channel if (!k.isValid()) { final EventLoop eventLoop; try { eventLoop = ch.eventLoop(); } catch (Throwable ignored) { // If the channel implementation throws an exception because there is no event loop, we ignore this // because we are only trying to determine if ch is registered to this event loop and thus has authority // to close ch. return; } // Only close ch if ch is still registered to this EventLoop. ch could have deregistered from the event loop // and thus the SelectionKey could be cancelled as part of the deregistration process, but the channel is // still healthy and should not be closed. // See if (eventLoop != this || eventLoop == null) { return; } // close the channel if the key is not valid anymore // 關閉channel unsafe.close(unsafe.voidPromise()); return; } try { // 獲取 SelectionKey 中所有準備就緒的操作集 int readyOps = k.readyOps(); // We first need to call finishConnect() before try to trigger a read(...) or write(...) as otherwise // the NIO JDK channel implementation may throw a NotYetConnectedException. // 在呼叫處理READ與WRITE事件之間,先呼叫finishConnect()介面,避免異常 NotYetConnectedException 發生。 if ((readyOps & SelectionKey.OP_CONNECT) != 0) { // remove OP_CONNECT as otherwise Selector.select(..) will always return without blocking // See int ops = k.interestOps(); ops &= ~SelectionKey.OP_CONNECT; k.interestOps(ops); unsafe.finishConnect(); } // Process OP_WRITE first as we may be able to write some queued buffers and so free memory. // 處理 WRITE 事件 if ((readyOps & SelectionKey.OP_WRITE) != 0) { // Call forceFlush which will also take care of clear the OP_WRITE once there is nothing left to write ch.unsafe().forceFlush(); } // Also check for readOps of 0 to workaround possible JDK bug which may otherwise lead // to a spin loop // 處理 ACCEPT 與 READ 事件 // 如果當前的EventLoop是WorkGroup,則表示有 READ 事件 // 如果當前的EventLoop是BossGroup,則表示有 ACCEPT 事件,有新連線進來了 if ((readyOps & (SelectionKey.OP_READ | SelectionKey.OP_ACCEPT)) != 0 || readyOps == 0) { // 讀取資料 unsafe.read(); } } catch (CancelledKeyException ignored) { unsafe.close(unsafe.voidPromise()); } }
關於
unsafe.read()
的分析,請看
執行所有任務
接下來,我們瞭解一下執行具體Task任務的介面:runAllTasks。在EventLoop中,待執行的任務佇列分為兩種:一種是普通任務佇列,一種是定時任務佇列。
我們講 EventLoop 建立時提到過NioEventLoop中 taskQueue 的建立,是一個MpscQueue,關於高效率的MpscQueue 後面單獨寫文章進行介紹:
public abstract class SingleThreadEventExecutor extends AbstractScheduledEventExecutor implements OrderedEventExecutor { ... // 存放普通任務的佇列 private final Queue<Runnable> taskQueue; ... protected SingleThreadEventExecutor(EventExecutorGroup parent, Executor executor, boolean addTaskWakesUp, int maxPendingTasks, RejectedExecutionHandler rejectedHandler) { super(parent); this.addTaskWakesUp = addTaskWakesUp; this.maxPendingTasks = Math.max(16, maxPendingTasks); this.executor = ObjectUtil.checkNotNull(executor, "executor"); // 建立TaskQueue taskQueue = newTaskQueue(this.maxPendingTasks); rejectedExecutionHandler = ObjectUtil.checkNotNull(rejectedHandler, "rejectedHandler"); } ... }public final class NioEventLoop extends SingleThreadEventLoop { ... // NioEventLoop 建立TaskQueue佇列 @Override protected Queue<Runnable> newTaskQueue(int maxPendingTasks) { // This event loop never calls takeTask() return maxPendingTasks == Integer.MAX_VALUE ? PlatformDependent.<Runnable>newMpscQueue() : PlatformDependent.<Runnable>newMpscQueue(maxPendingTasks); } ... }
存放定時任務的佇列在 AbstractScheduledEventExecutor 中,成員變數為 scheduledTaskQueue,程式碼如下:
public abstract class AbstractScheduledEventExecutor extends AbstractEventExecutor { // 優先順序佇列的比較器 private static final Comparator<ScheduledFutureTask<?>> SCHEDULED_FUTURE_TASK_COMPARATOR = new Comparator<ScheduledFutureTask<?>>() { @Override public int compare(ScheduledFutureTask<?> o1, ScheduledFutureTask<?> o2) { return o1.compareTo(o2); } }; // 存放定時任務的優先順序佇列 PriorityQueue<ScheduledFutureTask<?>> scheduledTaskQueue; // 建立定時任務佇列 PriorityQueue<ScheduledFutureTask<?>> scheduledTaskQueue() { if (scheduledTaskQueue == null) { scheduledTaskQueue = new DefaultPriorityQueue<ScheduledFutureTask<?>>( SCHEDULED_FUTURE_TASK_COMPARATOR, // Use same initial capacity as java.util.PriorityQueue 11); } return scheduledTaskQueue; } // 儲存定時任務 @Override public ScheduledFuture<?> schedule(Runnable command, long delay, TimeUnit unit) { ObjectUtil.checkNotNull(command, "command"); ObjectUtil.checkNotNull(unit, "unit"); if (delay < 0) { delay = 0; } validateScheduled0(delay, unit); return schedule(new ScheduledFutureTask<Void>( this, command, null, ScheduledFutureTask.deadlineNanos(unit.toNanos(delay)))); } // 儲存定時任務 @Override public <V> ScheduledFuture<V> schedule(Callable<V> callable, long delay, TimeUnit unit) { ObjectUtil.checkNotNull(callable, "callable"); ObjectUtil.checkNotNull(unit, "unit"); if (delay < 0) { delay = 0; } validateScheduled0(delay, unit); return schedule(new ScheduledFutureTask<V>( this, callable, ScheduledFutureTask.deadlineNanos(unit.toNanos(delay)))); } // 儲存定時任務 <V> ScheduledFuture<V> schedule(final ScheduledFutureTask<V> task) { // 判斷是否為當前執行緒 if (inEventLoop()) { // 新增定時任務佇列 scheduledTaskQueue().add(task); } else { execute(new Runnable() { @Override public void run() { // 新增定時任務佇列 scheduledTaskQueue().add(task); } }); } return task; } }
Netty存放定時任務佇列為 ,定時任務的封裝物件為 ScheduledFutureTask ,在佇列中的優先按照它們的截止時間進行排序,其次在按照id進行排序。
final class ScheduledFutureTask<V> extends PromiseTask<V> implements ScheduledFuture<V>, PriorityQueueNode { ... // 比較 ScheduledFutureTask 之間的排序 @Override public int compareTo(Delayed o) { if (this == o) { return 0; } ScheduledFutureTask<?> that = (ScheduledFutureTask<?>) o; long d = deadlineNanos() - that.deadlineNanos(); if (d < 0) { return -1; } else if (d > 0) { return 1; } else if (id < that.id) { return -1; } else if (id == that.id) { throw new Error(); } else { return 1; } } ... }
再來看看任務的執行邏輯,首先將定時任務取出,聚合到普通任務佇列中,再去for迴圈執行每個Task。
protected boolean runAllTasks(long timeoutNanos) { // 將定時任務從定時佇列中取出,放入普通佇列中 fetchFromScheduledTaskQueue(); // 從佇列中取出任務 Runnable task = pollTask(); if (task == null) { afterRunningAllTasks(); return false; } // 計算任務執行的最大超時時間 final long deadline = ScheduledFutureTask.nanoTime() + timeoutNanos; // 任務計數 long runTasks = 0; // 最近一次任務執行的時間 long lastExecutionTime; for (;;) { // 執行任務 safeExecute(task); // 任務計數 +1 runTasks ++; // Check timeout every 64 tasks because nanoTime() is relatively expensive. // XXX: Hard-coded value - will make it configurable if it is really a problem. // 由於nanoTime() 是非常好效能的操作,因此每64次就對比一下 定時任務的執行時間與 deadline, // 如果 lastExecutionTime >= deadline,則表示任務超時了,需要中斷退出 if ((runTasks & 0x3F) == 0) { lastExecutionTime = ScheduledFutureTask.nanoTime(); if (lastExecutionTime >= deadline) { break; } } // 獲取任務 task = pollTask(); if (task == null) { lastExecutionTime = ScheduledFutureTask.nanoTime(); break; } } afterRunningAllTasks(); // 記錄最後一次的執行時間 this.lastExecutionTime = lastExecutionTime; return true; }// 取出任務protected Runnable pollTask() { assert inEventLoop(); return pollTaskFrom(taskQueue); }// 從佇列中取出任務protected static Runnable pollTaskFrom(Queue<Runnable> taskQueue) { for (;;) { Runnable task = taskQueue.poll(); if (task == WAKEUP_TASK) { continue; } return task; } }// 將定時任務從定時佇列中取出,聚合到普通佇列中:private boolean fetchFromScheduledTaskQueue() { // 得到nanoTime = 當前時間 - ScheduledFutureTask的START_TIME(開始時間) long nanoTime = AbstractScheduledEventExecutor.nanoTime(); // 獲得截止時間小於nanoTime的定時任務 Runnable scheduledTask = pollScheduledTask(nanoTime); while (scheduledTask != null) { // 將定時任務放入普通佇列中,以備執行 if (!taskQueue.offer(scheduledTask)) { // No space left in the task queue add it back to the scheduledTaskQueue so we pick it up again. // 如果 taskQueue 沒有足夠的空間,導致新增失敗,則將其返回定時任務佇列中 scheduledTaskQueue().add((ScheduledFutureTask<?>) scheduledTask); return false; } scheduledTask = pollScheduledTask(nanoTime); } return true; }// 獲得截止時間小於nanoTime的定時任務protected final Runnable pollScheduledTask(long nanoTime) { assert inEventLoop(); // 獲取定時任務佇列 Queue<ScheduledFutureTask<?>> scheduledTaskQueue = this.scheduledTaskQueue; // 獲取第一個定時任務 ScheduledFutureTask<?> scheduledTask = scheduledTaskQueue == null ? null : scheduledTaskQueue.peek(); if (scheduledTask == null) { return null; } // 如果該定時任務的截止時間 <= nanoTime ,則返回 if (scheduledTask.deadlineNanos() <= nanoTime) { scheduledTaskQueue.remove(); return scheduledTask; } return null; }
來自 “ ITPUB部落格 ” ,連結:http://blog.itpub.net/31557424/viewspace-2218385/,如需轉載,請註明出處,否則將追究法律責任。
相關文章
- Netty NioEventLoop 建立過程原始碼分析NettyOOP原始碼
- Netty原始碼分析之NioEventLoop(三)—NioEventLoop的執行Netty原始碼OOP
- Netty服務端啟動過程相關原始碼分析Netty服務端原始碼
- Netty原始碼解析 -- 服務端啟動過程Netty原始碼服務端
- Spring啟動過程——原始碼分析Spring原始碼
- NioEventLoop啟動流程原始碼解析OOP原始碼
- Spring Boot原始碼分析-啟動過程Spring Boot原始碼
- Spring MVC 啟動過程原始碼分析SpringMVC原始碼
- Netty入門一:服務端應用搭建 & 啟動過程原始碼分析Netty服務端原始碼
- Netty啟動流程及原始碼分析Netty原始碼
- Spring啟動過程——原始碼分析(finishBeanFactoryInitialization(beanFactory))Spring原始碼Bean
- Netty學習筆記(五)NioEventLoop啟動Netty筆記OOP
- React Native Android 原始碼分析之啟動過程React NativeAndroid原始碼
- Android系統原始碼分析--Activity啟動過程Android原始碼
- Spring啟動過程原始碼分析基本概念Spring原始碼
- Netty原始碼分析(三):客戶端啟動Netty原始碼客戶端
- Netty原始碼分析(二):服務端啟動Netty原始碼服務端
- Hive原始碼分析(1)——HiveServer2啟動過程Hive原始碼Server
- Androd 系統原始碼-3:應用啟動過程的原始碼分析原始碼
- 精盡Spring Boot原始碼分析 - SpringApplication 啟動類的啟動過程Spring Boot原始碼APP
- 【原始碼】Redis Server啟動過程原始碼RedisServer
- Android系統原始碼分析–Zygote和SystemServer啟動過程Android原始碼GoServer
- [原始碼分析] 訊息佇列 Kombu 之 啟動過程原始碼佇列
- 走近原始碼:Redis的啟動過程原始碼Redis
- 原始碼|HDFS之NameNode:啟動過程原始碼
- 以太坊啟動過程原始碼解析原始碼
- SpringMVC原始碼解析(1)-啟動過程SpringMVC原始碼
- Redis核心原理與實踐--Redis啟動過程原始碼分析Redis原始碼
- netty原始碼分析之服務端啟動全解析Netty原始碼服務端
- Netty原始碼學習系列之5-NioEventLoop的run方法Netty原始碼OOP
- tomcat原始碼分析(第二篇 tomcat啟動過程詳解)Tomcat原始碼
- spring原始碼閱讀--容器啟動過程Spring原始碼
- Linux 啟動過程分析Linux
- Liferay 啟動過程分析
- 漲姿勢:Spring Boot 2.x 啟動全過程原始碼分析Spring Boot原始碼
- Netty原始碼解析 -- ChannelOutboundBuffer實現與Flush過程Netty原始碼
- SOFAJRaft原始碼閱讀-模組啟動過程Raft原始碼
- Netty Channel原始碼分析Netty原始碼