Okhttp源码分析

版本号:3.13.1

一.基本使用

//1.创建OkHttpClient对象
val okHttpClient = OkHttpClient.Builder().readTimeout(5,TimeUnit.SECONDS).build()
//2.创建Request对象
val request = Request.Builder().url("www.baidu.com").build()
//3.通过OkHttpClient将Request封装成Call对象
val call = okHttpClient.newCall(request)
//通过Call执行请求
//同步请求
val response = call.execute()
Log.d("okhttp",response.body().toString())
//异步请求
call.enqueue(object :Callback{
    override fun onFailure(call: Call, e: IOException) {
    }

    override fun onResponse(call: Call, response: Response) {
        Log.d("okhttp",response.body().toString())
    }
})

Call可以理解为RequestResponse之间的桥梁,Http请求过程中可能有重定向和重试等操作,你的一个简单请求可能会产生多个请求和响应。OkHttp使用Call这一概念对此来建模:不论为了满足你的请求任务,中间做了多少次请求和响应,都算作一个Call

二.源码分析

1.创建对象源码分析

不管是同步请求还是异步请求,都必须先创建OkHttpClientRequest对象,上面使用Build模式创建的,下面分别看一下各自的源码:

OkHttpClient.Builder().

public Builder() {
  //任务分发器
  dispatcher = new Dispatcher();
  protocols = DEFAULT_PROTOCOLS;
  connectionSpecs = DEFAULT_CONNECTION_SPECS;
  eventListenerFactory = EventListener.factory(EventListener.NONE);
  proxySelector = ProxySelector.getDefault();
  if (proxySelector == null) {
    proxySelector = new NullProxySelector();
  }
  cookieJar = CookieJar.NO_COOKIES;
  socketFactory = SocketFactory.getDefault();
  hostnameVerifier = OkHostnameVerifier.INSTANCE;
  certificatePinner = CertificatePinner.DEFAULT;
  proxyAuthenticator = Authenticator.NONE;
  authenticator = Authenticator.NONE;
  //连接池
  connectionPool = new ConnectionPool();
  dns = Dns.SYSTEM;
  followSslRedirects = true;
  followRedirects = true;
  retryOnConnectionFailure = true;
  callTimeout = 0;
  //java7以后在数字中可以使用下划线,只是增加阅读性,没其他作用
  connectTimeout = 10_000;
  readTimeout = 10_000;
  writeTimeout = 10_000;
  pingInterval = 0;
}

Request.Builder()

public Builder() {
  this.method = "GET";
  this.headers = new Headers.Builder();
}

build()方法,都是在该方法中创建各自的对象,在构造方法中将当前的build对象传入,然后把对应的属性值赋。下面以Request为例:

public Request build() {
  if (url == null) throw new IllegalStateException("url == null");
  return new Request(this);
}
//Builder模式
Request(Builder builder) {
this.url = builder.url;
this.method = builder.method;
this.headers = builder.headers.build();
this.body = builder.body;
this.tags = Util.immutableMap(builder.tags);
}

不管同步请求还是异步请求,都是调用Call的方法执行的,下面看一下Call对象的创建okHttpClient.newCall(request)

@Override public Call newCall(Request request) {
    //Call是一个接口,RealCall是它的实现类
    return RealCall.newRealCall(this, request, false /* for web socket */);
}

static RealCall newRealCall(OkHttpClient client, Request originalRequest, boolean forWebSocket) {
    // Safely publish the Call instance to the EventListener.
    //创建RealCall对象,将client和request传入
    RealCall call = new RealCall(client, originalRequest, forWebSocket);
    //设置监听器
    call.eventListener = client.eventListenerFactory().create(call);
    return call;
}

private RealCall(OkHttpClient client, Request originalRequest, boolean forWebSocket) {
    this.client = client;
    this.originalRequest = originalRequest;
    this.forWebSocket = forWebSocket;
    //重定向拦截器
    this.retryAndFollowUpInterceptor = new RetryAndFollowUpInterceptor(client);
    this.timeout = new AsyncTimeout() {
        @Override protected void timedOut() {
         cancel();
        }
    };
    this.timeout.timeout(client.callTimeoutMillis(), MILLISECONDS);
}

从上面代码中可以看到Call的实现类为RealCall,它持有clientrequest

上面创建对象的源码已经分析完了,下面就看一下具体请求的方法。

2.同步请求:call.execute()

@Override public Response execute() throws IOException {
    synchronized (this) {
      //同一个请求执行执行一遍,否则跑出异常
      if (executed) throw new IllegalStateException("Already Executed");
      executed = true;
    }
    ......
    //当执行的请求开始的时候,回调监听中的方法
    eventListener.callStart(this);
    try {
      //真正的请求是dispatcher.executed
      client.dispatcher().executed(this);
      Response result = getResponseWithInterceptorChain();
      if (result == null) throw new IOException("Canceled");
      return result;
    }......
   finally {
     //执行完成以后从对列中移除请求
      client.dispatcher().finished(this);
    }
}

public Dispatcher dispatcher() {
   return dispatcher;
}

//dispatcher.executed
synchronized void executed(RealCall call) {
    //将call加入到同步请求对列中
    runningSyncCalls.add(call);
}

public final class Dispatcher {
  ......
  //异步就绪对列
  private final Deque<AsyncCall> readyAsyncCalls = new ArrayDeque<>();
  //异步执行对列
  private final Deque<AsyncCall> runningAsyncCalls = new ArrayDeque<>();
  //同步执行对列
  private final Deque<RealCall> runningSyncCalls = new ArrayDeque<>();
  ......
}

同步请求调用realCall.executed方法,在该方法中调用dispatcher.executedrealCall添加到同步运行对列中runningSyncCalls然后调用getResponseWithInterceptorChain获取响应报文。

3.异步请求: call.enqueue

@Override public void enqueue(Callback responseCallback) {
    synchronized (this) {
      //当前的call(创建的call)只能执行一次
      if (executed) throw new IllegalStateException("Already Executed");
      executed = true;
    }
    captureCallStackTrace();
    eventListener.callStart(this);
    //封装成了AsyncCall,它就是一个Runable
    client.dispatcher().enqueue(new AsyncCall(responseCallback));
}
void enqueue(AsyncCall call) {
    synchronized (this) {
      //添加到就绪对列
      readyAsyncCalls.add(call);
      ......
      }
    }
    promoteAndExecute();
}

private boolean promoteAndExecute() {
    assert (!Thread.holdsLock(this));
    List<AsyncCall> executableCalls = new ArrayList<>();
    boolean isRunning;
    synchronized (this) {
      //遍历就绪对列执行任务
      for (Iterator<AsyncCall> i = readyAsyncCalls.iterator(); i.hasNext(); ) {
        AsyncCall asyncCall = i.next();
        //如果请求大于最大的请求数 maxRequests = 64,不执行
        if (runningAsyncCalls.size() >= maxRequests) break; // Max capacity.
        //请求的host不能大于maxRequestsPerHost = 5
        if (asyncCall.callsPerHost().get() >= maxRequestsPerHost) continue; // Host max capacity.
        i.remove();
        asyncCall.callsPerHost().incrementAndGet();
        //没有大于最大请求数,添加到执行对列中
        executableCalls.add(asyncCall);
        runningAsyncCalls.add(asyncCall);
      }
      isRunning = runningCallsCount() > 0;
    }
    //循环执行对列,执行具体的请求
    for (int i = 0, size = executableCalls.size(); i < size; i++) {
      AsyncCall asyncCall = executableCalls.get(i);
      //执行任务,传入线程池
      asyncCall.executeOn(executorService());
    }
    return isRunning;
}

异步请求的时候,通过dispatcher.enqueue方法将call(封装成了Runable(AsyncCall,它是RealCall的的内部类))添加到就绪对列中,然后循环就绪对列,如果现在执行的任务数没有超过最大的请求数(64)就添加到执行对列中,然后执行asyncCall.executeOn(executorService());

public synchronized ExecutorService executorService() {
    if (executorService == null) {
     //最大的线程数为 Integer.MAX_VALUE,上面已经限制最大的请求数为64所以这里的数量不会超过64
      executorService = new ThreadPoolExecutor(0, Integer.MAX_VALUE, 60, TimeUnit.SECONDS,
          new SynchronousQueue<>(), Util.threadFactory("OkHttp Dispatcher", false));
    }
    return executorService;
}

void executeOn(ExecutorService executorService) {
  assert (!Thread.holdsLock(client.dispatcher()));
  boolean success = false;
  try {
    //执行任务
    executorService.execute(this);
    success = true;
  } catch (RejectedExecutionException e) {
    InterruptedIOException ioException = new InterruptedIOException("executor rejected");
    ioException.initCause(e);
    eventListener.callFailed(RealCall.this, ioException);
    responseCallback.onFailure(RealCall.this, ioException);
  } finally {
    if (!success) {
      client.dispatcher().finished(this); // This call is no longer running!
    }
  }
}

executorService.execute(this);就是执行AsyncCall中的run()方法

AsyncCall继承NamedRunnable,没有重写run()方法,直接调用父类的,在父类的run()方法中调用了一个execute();方法,该方法是一个抽象方法,需要子类实现,所以实际执行的是AsyncCall.execute()

public abstract class NamedRunnable implements Runnable {
  ......
  @Override public final void run() {
    String oldName = Thread.currentThread().getName();
    Thread.currentThread().setName(name);
    try {
      execute();
    } finally {
      Thread.currentThread().setName(oldName);
    }
  }
  protected abstract void execute();
}

下面就看一个AsyncCall.execute(),真正执行任务的方法:

//该方法在子线程中执行
@Override protected void execute() {
      boolean signalledCallback = false;
      timeout.enter();
      try {
        //获取响应报文
        Response response = getResponseWithInterceptorChain();
        if (retryAndFollowUpInterceptor.isCanceled()) {
          signalledCallback = true;
          responseCallback.onFailure(RealCall.this, new IOException("Canceled"));
        } else {
          signalledCallback = true;
          responseCallback.onResponse(RealCall.this, response);
        }
      }......
      finally {
        //调用finished方法,将该请求从请求对列中移除
        client.dispatcher().finished(this);
      }
    }
}

从上面的代码分析我们可以得出:异步请求流程call.enqueue->realCall.enqueue->dispatcher.enqueue(AsyncCall call)(AsyncCall本质就是一个Runable)在dispatcher.enqueue方法中将call添加到就绪对列中,然后外遍历就绪对列,如果现在运行的任务没有超过最大请求数(64)就会把它加入到运行对列中runningAsyncCalls,然后调用asyncCall.executeOn(executorService())(executorService()方法就是创建一个线程池),在executeOn方法中会执行asyncCall,就是调用它的execute方法。在该方法中真正的去执行任务,该方法是在子线程中执行的。

通过上面的分析我们可以得出大致的请求流程图如下:

请求流程图

不管是同步请求还是异步请求,都调用了dispatcher对应的方法,它里面维护了三个任务对列和一个线程池(用来执行异步请求),dispatcher维护着请求任务的添加和移除。

三.Okhttp中的拦截器

拦截器Okhttp提供的一种强大的机制,它可以实现网络监听、请求以及响应重写、请求失败重试等功能。

Okhttp拦截器分为两种:一种是应用拦截器(就是我们自定义的拦截器),另一种就是网络拦截器(是Okhttp内部提供给我们的拦截器,真正的网络请求就是通过这些网络拦截器来实现的)。

从上面的代码分析得出:不管是同步请求还是异步请求,最终都是通过getResponseWithInterceptorChain()方法来获取Response的,该方法就是构建一个拦截器链。下面看一下该方法的代码:

//RealCall中的方法
Response getResponseWithInterceptorChain() throws IOException {
    List<Interceptor> interceptors = new ArrayList<>();
    //添加自定义的拦截器
    interceptors.addAll(client.interceptors());
    //添加okhttp提供给我们的网络拦截器
    interceptors.add(retryAndFollowUpInterceptor);
    interceptors.add(new BridgeInterceptor(client.cookieJar()));
    interceptors.add(new CacheInterceptor(client.internalCache()));
    interceptors.add(new ConnectInterceptor(client));
    if (!forWebSocket) {
      interceptors.addAll(client.networkInterceptors());
    }
    interceptors.add(new CallServerInterceptor(forWebSocket));
    //创建一个拦截器链对象,然后将拦截器集合传入
    Interceptor.Chain chain = new RealInterceptorChain(interceptors, null, null, null, 0,
        originalRequest, this, eventListener, client.connectTimeoutMillis(),
        client.readTimeoutMillis(), client.writeTimeoutMillis());
    return chain.proceed(originalRequest);
}

创建好拦截器链以后调用了该对象的chain.proceed(originalRequest)方法。该方法源码如下:

public Response proceed(Request request, StreamAllocation streamAllocation, HttpCodec httpCodec,
  RealConnection connection) throws IOException {
    ......
    //又创建了一个拦截器链对象,注意此时传入的index = index + 1
    RealInterceptorChain next = new RealInterceptorChain(interceptors, streamAllocation, httpCodec,
        connection, index + 1, request, call, eventListener, connectTimeout, readTimeout,
        writeTimeout);
    //顺序获取拦截器,然后调用拦截器的intercept方法
    Interceptor interceptor = interceptors.get(index);
    Response response = interceptor.intercept(next);
    ......
    return response;
}

chain.proceed方法中调用了interceptor.intercept(next);方法,并将新创建的拦截器链对象传入,此时index为index + 1,这样就构成了依次调用拦截器集合的所用拦截器的intercept方法。在该方法中完成对应的功能以后,调用下一个拦截器的intercept方法,并将处理后的Response返回给上一个拦截器

拦截器处理流程图

1.RetryAndFollowUpInterceptor(重定向拦截器)

该拦截器的主要作用就是:负责请求的重定向操作以及请求失败后的重试机制。

@Override public Response intercept(Chain chain) throws IOException {
    Request request = chain.request();
    RealInterceptorChain realChain = (RealInterceptorChain) chain;
    Call call = realChain.call();
    EventListener eventListener = realChain.eventListener();
    //1.创建StreamAllocation 对象,该对象用于分配请求过程中的流
    StreamAllocation streamAllocation = new StreamAllocation(client.connectionPool(),
        createAddress(request.url()), call, eventListener, callStackTrace);
    this.streamAllocation = streamAllocation;
    //重连次数
    int followUpCount = 0;
    Response priorResponse = null;
    while (true) {
      ......
      Response response;
      boolean releaseConnection = true;
      try {
        //2.调用RealInterceptorChain的proceed方法进行网络请求
        response = realChain.proceed(request, streamAllocation, null, null);
        releaseConnection = false;
      }......
      // 叠加先前的响应
      if (priorResponse != null) {
        response = response.newBuilder()
            .priorResponse(priorResponse.newBuilder()
                    .body(null)
                    .build())
            .build();
      }
      Request followUp;
      try {
        //根据响应判断是否需要重新请求
        followUp = followUpRequest(response, streamAllocation.route());
      }......
      if (followUp == null) {
        //不需要重新请求,直接返回response,结束while循环
        streamAllocation.release(true);
        return response;
      }
      ......
      //需要重新请求,先判断重新请求的次数是否超过设置的最大值,MAX_FOLLOW_UPS = 20
      if (++followUpCount > MAX_FOLLOW_UPS) {
        //超过最大的重新请求次数,抛出异常
        streamAllocation.release(true);
        throw new ProtocolException("Too many follow-up requests: " + followUpCount);
      }
      ......
     //重新请求
     if (!sameConnection(response, followUp.url())) {
        streamAllocation.release(false);
        streamAllocation = new StreamAllocation(client.connectionPool(),
            createAddress(followUp.url()), call, eventListener, callStackTrace);
        this.streamAllocation = streamAllocation;
      }......
      request = followUp;
      priorResponse = response;
    }
}

RetryAndFollowUpInterceptor.intercept方法得出主要做了以下几件事:

  • 1.创建StreamAllocation对象。
  • 2.调用RealInterceptorChainproceed方法进行网络请求,该方法就会调用下一个拦截器intercept方法,依次调用,获取对应的Response

intercept方法有些类似递归调用,这里是不同拦截器对象的intercept方法,这样就从上到下形成了一个链。

  • 3.根据异常结果或者响应结果判断是否要进行重新请求。

2.BridgeInterceptor(桥接拦截器)

该拦截器的作用主要就是处理请求和响应

RetryAndFollowUpInterceptor拦截器中创建StreamAllocation对象以后,就会调用chain.proceed方法进行网络请求,其实就是调用下一个拦截器的intercept方法,RetryAndFollowUpInterceptor的下一个拦截就是BridgeInterceptor,下面看一下它的intercept代码:

@Override public Response intercept(Chain chain) throws IOException {
    Request userRequest = chain.request();
    Request.Builder requestBuilder = userRequest.newBuilder();
    RequestBody body = userRequest.body();
    //1.为请求添加一些头信息
    if (body != null) {
      MediaType contentType = body.contentType();
      if (contentType != null) {
        requestBuilder.header("Content-Type", contentType.toString());
      }
      long contentLength = body.contentLength();
      if (contentLength != -1) {
        requestBuilder.header("Content-Length", Long.toString(contentLength));
        requestBuilder.removeHeader("Transfer-Encoding");
      } else {
        requestBuilder.header("Transfer-Encoding", "chunked");
        requestBuilder.removeHeader("Content-Length");
      }
    }
    if (userRequest.header("Host") == null) {
      requestBuilder.header("Host", hostHeader(userRequest.url(), false));
    }
    if (userRequest.header("Connection") == null) {
      requestBuilder.header("Connection", "Keep-Alive");
    }
    // If we add an "Accept-Encoding: gzip" header field we're responsible for also decompressing
    // the transfer stream.
    boolean transparentGzip = false;
    if (userRequest.header("Accept-Encoding") == null && userRequest.header("Range") == null) {
      transparentGzip = true;
      requestBuilder.header("Accept-Encoding", "gzip");
    }

    List<Cookie> cookies = cookieJar.loadForRequest(userRequest.url());
    if (!cookies.isEmpty()) {
      requestBuilder.header("Cookie", cookieHeader(cookies));
    }

    if (userRequest.header("User-Agent") == null) {
      requestBuilder.header("User-Agent", Version.userAgent());
    }
    //2.发送网络请求
    Response networkResponse = chain.proceed(requestBuilder.build());
    //3.解压响应数据,支持`gzip`,所以需要解压
    HttpHeaders.receiveHeaders(cookieJar, userRequest.url(), networkResponse.headers());
    Response.Builder responseBuilder = networkResponse.newBuilder()
        .request(userRequest);
    if (transparentGzip
        && "gzip".equalsIgnoreCase(networkResponse.header("Content-Encoding"))
        && HttpHeaders.hasBody(networkResponse)) {
      GzipSource responseBody = new GzipSource(networkResponse.body().source());
      Headers strippedHeaders = networkResponse.headers().newBuilder()
          .removeAll("Content-Encoding")
          .removeAll("Content-Length")
          .build();
      responseBuilder.headers(strippedHeaders);
      String contentType = networkResponse.header("Content-Type");
      responseBuilder.body(new RealResponseBody(contentType, -1L, Okio.buffer(responseBody)));
    }

    return responseBuilder.build();
}

BridgeInterceptor.intercept方法得出主要做了以下几件事:

  • 1.将用户构建的Request转化为能够进行网络访问的请求(添加一些头信息,如:ConnectionAccept-EncodingHost等)。
  • 2.将设置好的Request发送网络请求(调用chan.proceed)。
  • 3.将请求返回的Response转化为用户可用的Response(可能使用gzip压缩,需要解压)。

3.CacheInterceptor(缓存拦截器)

该拦截器的作用主要就是处理数据的缓存

BridgeInterceptor.intercept方法中构建好Request后就发送请求,就会调用CacheInterceptor.intercept方法,该方法的代码为:

@Override public Response intercept(Chain chain) throws IOException {
    //如果设置了缓存就获取缓存
    Response cacheCandidate = cache != null
        ? cache.get(chain.request())
        : null;

    long now = System.currentTimeMillis();
    //获取缓存策略,里面维护着一个networkRequest和cacheResponse
    CacheStrategy strategy = new CacheStrategy.Factory(now, chain.request(), cacheCandidate).get();
    Request networkRequest = strategy.networkRequest;
    Response cacheResponse = strategy.cacheResponse;
    if (cache != null) {
      //如果有缓存,跟新一下缓存的各项指标,主要是缓存命中率
      cache.trackResponse(strategy);
    }
    if (cacheCandidate != null && cacheResponse == null) {
      //有缓存,但是对应的Response 为null即缓存不符合要求,关闭该缓存
      closeQuietly(cacheCandidate.body()); // The cache candidate wasn't applicable. Close it.
    }

    // 如果此时网络不可用,同时缓存不可用,抛出一个504的错误
    if (networkRequest == null && cacheResponse == null) {
      return new Response.Builder()
          .request(chain.request())
          .protocol(Protocol.HTTP_1_1)
          .code(504)
          .message("Unsatisfiable Request (only-if-cached)")
          .body(Util.EMPTY_RESPONSE)
          .sentRequestAtMillis(-1L)
          .receivedResponseAtMillis(System.currentTimeMillis())
          .build();
    }

    //网络不可用,但是有缓存,直接返回缓存。
    if (networkRequest == null) {
      return cacheResponse.newBuilder()
          .cacheResponse(stripBody(cacheResponse))
          .build();
    }
    //没有缓存,但是网路可用,发起网络请求
    Response networkResponse = null;
    try {
      networkResponse = chain.proceed(networkRequest);
    } finally {
      // If we're crashing on I/O or otherwise, don't leak the cache body.
      if (networkResponse == null && cacheCandidate != null) {
        closeQuietly(cacheCandidate.body());
      }
    }

    if (cacheResponse != null) {
      //如果网络请求返回的状态码为 HTTP_NOT_MODIFIED = 304,从缓存中获取数据
      if (networkResponse.code() == HTTP_NOT_MODIFIED) {
        Response response = cacheResponse.newBuilder()
            .headers(combine(cacheResponse.headers(), networkResponse.headers()))
            .sentRequestAtMillis(networkResponse.sentRequestAtMillis())
            .receivedResponseAtMillis(networkResponse.receivedResponseAtMillis())
            .cacheResponse(stripBody(cacheResponse))
            .networkResponse(stripBody(networkResponse))
            .build();
        networkResponse.body().close();
        ......
    }

    Response response = networkResponse.newBuilder()
        .cacheResponse(stripBody(cacheResponse))
        .networkResponse(stripBody(networkResponse))
        .build();

    if (cache != null) {
      //如果请求可以缓存,就将网络请求后的数据添加到缓存
      if (HttpHeaders.hasBody(response) && CacheStrategy.isCacheable(response, networkRequest)) {
        // Offer this request to the cache.
        CacheRequest cacheRequest = cache.put(response);
        return cacheWritingResponse(cacheRequest, response);
      }
      //如果请求方法缓存无效,从缓存中删除
      if (HttpMethod.invalidatesCache(networkRequest.method())) {
        try {
          cache.remove(networkRequest);
        } catch (IOException ignored) {
          // The cache cannot be written.
        }
      }
    }

    return response;
}

从上面代码可以得出CacheInterceptor的处理逻辑为:

  • 1.如果网络不可用,同时没有缓存,会返回一个504的响应码。
  • 2.如果网络不可用,但是有缓存,直接返回缓存的数据。
  • 3.如果网络可用,发送网络请求(调用chain.proceed)。
    • 如果有缓存并且网络请求返回的状态码为 HTTP_NOT_MODIFIED = 304,就从缓存中获取数据。
    • 如果没有缓存,就返回网络请求的数据。此时如果设置了缓存,就将网络请求后的数据添加到缓存中(cache.put(response)

缓存的管理使用的Cache类中响应的方法(getput),我们先看一下怎么使用缓存:

val okHttpClient = OkHttpClient.Builder()
              .readTimeout(5,TimeUnit.SECONDS)
              .cache(Cache(File("cache"),24 * 1024 * 1024))//通过配置Cache对象
              .build()

下面我们就看一下Cache这个类的源码:

@Nullable CacheRequest put(Response response) {
    String requestMethod = response.request().method();

    if (HttpMethod.invalidatesCache(response.request().method())) {
      try {
        remove(response.request());
      } catch (IOException ignored) {
        // The cache cannot be written.
      }
      return null;
    }
    //只缓存GET请求
    if (!requestMethod.equals("GET")) {
      return null;
    }
    //Vary的内容会作为当前缓存数据是否可以作为请求结果返回给客户端的判断
    //Vary详解:https://blog.csdn.net/qq_29405933/article/details/84315254
    if (HttpHeaders.hasVaryAll(response)) {
      return null;
    }
    //缓存数据的实体对象
    Entry entry = new Entry(response);
    //使用磁盘缓存DiskLruCache来实现缓存功能
    DiskLruCache.Editor editor = null;
    try {
      editor = cache.edit(key(response.request().url()));
      if (editor == null) {
        return null;
      }
      entry.writeTo(editor);
      return new CacheRequestImpl(editor);
    }......
}

从上述代码可以看出Okhttp中的缓存使用的是DiskLruCache

4.ConnectInterceptor(连接拦截器)

该拦截器的作用主要就是建立与服务器的连接(Socket)

如果没有缓存,但是网络可用的情况下就会调用ConnectInterceptor.intercept方法,下面看一下该方法的代码:

@Override public Response intercept(Chain chain) throws IOException {
    RealInterceptorChain realChain = (RealInterceptorChain) chain;
    Request request = realChain.request();
    //获取StreamAllocation对象,该对象是在RetryAndFollowUpInterceptor中实例化的
    StreamAllocation streamAllocation = realChain.streamAllocation();
    // We need the network to satisfy this request. Possibly for validating a conditional GET.
    boolean doExtensiveHealthChecks = !request.method().equals("GET");
    //创建HttpCodec对象,该对象用于请求和响应的处理
    HttpCodec httpCodec = streamAllocation.newStream(client, chain, doExtensiveHealthChecks);
    //创建用于网络IO的RealConnection对象
    RealConnection connection = streamAllocation.connection();
    //调用后面拦截的intercept方法并传递对应的参数,发起网络请求
    return realChain.proceed(request, streamAllocation, httpCodec, connection);
}

下面重点看一下streamAllocation.newStream方法:

public HttpCodec newStream(
  OkHttpClient client, Interceptor.Chain chain, boolean doExtensiveHealthChecks) {
    ......
    try {
      //获取一个RealConnection对象
      RealConnection resultConnection = findHealthyConnection(connectTimeout, readTimeout,
          writeTimeout, pingIntervalMillis, connectionRetryEnabled, doExtensiveHealthChecks);
      //通过RealConnection对象创建HttpCodec对象
      HttpCodec resultCodec = resultConnection.newCodec(client, chain, this);
      synchronized (connectionPool) {
        codec = resultCodec;
        return resultCodec;
      }
    } catch (IOException e) {
      throw new RouteException(e);
    }
}

findHealthyConnection方法会调用findConnection方法来获取一个RealConnection对象,代码如下:

private RealConnection findConnection(int connectTimeout, int readTimeout, int writeTimeout,
  int pingIntervalMillis, boolean connectionRetryEnabled) throws IOException {
    ......
    synchronized (connectionPool) {
      ......
      if (this.connection != null) {
        //如果能复用就复用,this代表的是StreamAllocation对象
        result = this.connection;
        releasedConnection = null;
      }
      ......
    }
    ......
    不能复用从连接池中找
    synchronized (connectionPool) {
      if (canceled) throw new IOException("Canceled");
      if (newRouteSelection) {
        List<Route> routes = routeSelection.getAll();
        for (int i = 0, size = routes.size(); i < size; i++) {
          Route route = routes.get(i);
          Internal.instance.acquire(connectionPool, address, this, route);
          if (connection != null) {
            foundPooledConnection = true;
            result = connection;
            this.route = route;
            break;
          }
        }
      }
      if (!foundPooledConnection) {
        //连接池中没有就new一个
        if (selectedRoute == null) {
          selectedRoute = routeSelection.next();
        }
        route = selectedRoute;
        refusedStreamCount = 0;
        result = new RealConnection(connectionPool, selectedRoute);
        acquire(result, false);
      }
    }
    ......
    开启Socket连接
    result.connect(connectTimeout, readTimeout, writeTimeout, pingIntervalMillis,
        connectionRetryEnabled, call, eventListener);
    routeDatabase().connected(result.route());
    Socket socket = null;
    synchronized (connectionPool) {
      reportedAcquired = true;
      //connection将加入连接池中
      Internal.instance.put(connectionPool, result);
      ......
    }
    .......
    return result;
}

findConnection方法做的主要就是:

  • 1.如果StreamAllocation中的connection能复用就复用,不同复用的话就从连接池connectionPool中获取,如果连接池中没有就new一个,然后加入连接池中。
  • 最终调用RealConnectionconnect方法打开一个socket链接

获取resultConnection对象后然后调用resultConnection.newCodec来获取HttpCodec 对象

public HttpCodec newCodec(OkHttpClient client, Interceptor.Chain chain,
  StreamAllocation streamAllocation) throws SocketException {
    if (http2Connection != null) {
      return new Http2Codec(client, chain, streamAllocation, http2Connection);
    } else {
      socket.setSoTimeout(chain.readTimeoutMillis());
      source.timeout().timeout(chain.readTimeoutMillis(), MILLISECONDS);
      sink.timeout().timeout(chain.writeTimeoutMillis(), MILLISECONDS);
      return new Http1Codec(client, streamAllocation, source, sink);
    }
}

创建好RealConnectionHttpCodec对象以后,调用下一个拦截器intercept方法。下面我们最后一个拦截器:CallServerInterceptor

5.CallServerInterceptor(发起请求拦截器)

该拦截器的主要作用就是真正的向服务器写入请求数据和读取响应数据

该拦截器为Okhttp拦截器链的最后一个拦截器,该拦截器是真正向服务器发送请求和处理响应的地方。下面看一下它的intercept方法代码:

@Override public Response intercept(Chain chain) throws IOException {
    final RealInterceptorChain realChain = (RealInterceptorChain) chain;
    Call call = realChain.call();
    final HttpCodec httpCodec = realChain.httpStream();
    StreamAllocation streamAllocation = realChain.streamAllocation();
    RealConnection connection = (RealConnection) realChain.connection();
    Request request = realChain.request();
    ......
    //向socket中写入header数据
    httpCodec.writeRequestHeaders(request);
    ......
    Response.Builder responseBuilder = null;
    if (HttpMethod.permitsRequestBody(request.method()) && request.body() != null) {
      if ("100-continue".equalsIgnoreCase(request.header("Expect"))) {
        //如果请求头中有配置“Expect: 100-continue” ,直接读取响应头信息
        httpCodec.flushRequest();
        realChain.eventListener().responseHeadersStart(call);
        responseBuilder = httpCodec.readResponseHeaders(true);
      }

      if (responseBuilder == null) {
        if (request.body() instanceof DuplexRequestBody) {
          httpCodec.flushRequest();
          CountingSink requestBodyOut = new CountingSink(httpCodec.createRequestBody(request, -1L));
          BufferedSink bufferedRequestBody = Okio.buffer(requestBodyOut);
          //向socket写入请求体
          request.body().writeTo(bufferedRequestBody);
        } else {
          // Write the request body if the "Expect: 100-continue" expectation was met.
          realChain.eventListener().requestBodyStart(call);
          long contentLength = request.body().contentLength();
          CountingSink requestBodyOut =
              new CountingSink(httpCodec.createRequestBody(request, contentLength));
          BufferedSink bufferedRequestBody = Okio.buffer(requestBodyOut);

          request.body().writeTo(bufferedRequestBody);
          bufferedRequestBody.close();
          realChain.eventListener().requestBodyEnd(call, requestBodyOut.successfulCount);
        }
      }
      ......
    }

    if (!(request.body() instanceof DuplexRequestBody)) {
      //结束请求
      httpCodec.finishRequest();
    }

    //读取响应信息
    if (responseBuilder == null) {
      realChain.eventListener().responseHeadersStart(call);
      responseBuilder = httpCodec.readResponseHeaders(false);
    }

    responseBuilder
        .request(request)
        .handshake(streamAllocation.connection().handshake())
        .sentRequestAtMillis(sentRequestMillis)
        .receivedResponseAtMillis(System.currentTimeMillis());
    Internal.instance.initCodec(responseBuilder, httpCodec);
    Response response = responseBuilder.build();

    int code = response.code();
    if (code == 100) {
      // server sent a 100-continue even though we did not request one.
      // try again to read the actual response
      responseBuilder = httpCodec.readResponseHeaders(false);

      responseBuilder
          .request(request)
          .handshake(streamAllocation.connection().handshake())
          .sentRequestAtMillis(sentRequestMillis)
          .receivedResponseAtMillis(System.currentTimeMillis());
      Internal.instance.initCodec(responseBuilder, httpCodec);
      response = responseBuilder.build();
      code = response.code();
    }

    realChain.eventListener().responseHeadersEnd(call, response);

    if (forWebSocket && code == 101) {
      response = response.newBuilder()
          .body(Util.EMPTY_RESPONSE)
          .build();
    } else {
      //回去响应体数据
      response = response.newBuilder()
          .body(httpCodec.openResponseBody(response))
          .build();
    }
    ......
    return response;
}

从上面代码可以看出CallServerInterceptor主要就是向Socket中写入请求信息,然后读取响应信息,最后构建Response对象并返回给上一个拦截器

总结

至此Okhttp的关键代码已经分析完毕,我们可以得出Okhttp的一次请求过程大概是:

  • 1.将请求封装成Call对象
  • 2.通过Dispatcher对请求进行分发。
  • 3.调用RealCall对象的getResponseWithInterceptorChain方法获取Response
  • 4.getResponseWithInterceptorChain方法中会依次调用拦截器:RetryAndFollowUpInterceptor、BridgeInterceptor、CacheInterceptor、ConnectInterceptor、CallServerInterceptorintercept方法,完成对于请求信息的封装,发送和读取。

Kotlin项目实战

网络优化

HTTPDNS使用HTTP协议进行域名解析,代替现有基于UDP的DNS协议,域名解析请求直接发送到阿里云的HTTPDNS服务器,从而绕过运营商的Local DNS,能够避免Local DNS造成的域名劫持问题和调度不精准问题。

最后编辑于
©著作权归作者所有,转载或内容合作请联系作者
  • 序言:七十年代末,一起剥皮案震惊了整个滨河市,随后出现的几起案子,更是在滨河造成了极大的恐慌,老刑警刘岩,带你破解...
    沈念sama阅读 202,009评论 5 474
  • 序言:滨河连续发生了三起死亡事件,死亡现场离奇诡异,居然都是意外死亡,警方通过查阅死者的电脑和手机,发现死者居然都...
    沈念sama阅读 84,808评论 2 378
  • 文/潘晓璐 我一进店门,熙熙楼的掌柜王于贵愁眉苦脸地迎上来,“玉大人,你说我怎么就摊上这事。” “怎么了?”我有些...
    开封第一讲书人阅读 148,891评论 0 335
  • 文/不坏的土叔 我叫张陵,是天一观的道长。 经常有香客问我,道长,这世上最难降的妖魔是什么? 我笑而不...
    开封第一讲书人阅读 54,283评论 1 272
  • 正文 为了忘掉前任,我火速办了婚礼,结果婚礼上,老公的妹妹穿的比我还像新娘。我一直安慰自己,他们只是感情好,可当我...
    茶点故事阅读 63,285评论 5 363
  • 文/花漫 我一把揭开白布。 她就那样静静地躺着,像睡着了一般。 火红的嫁衣衬着肌肤如雪。 梳的纹丝不乱的头发上,一...
    开封第一讲书人阅读 48,409评论 1 281
  • 那天,我揣着相机与录音,去河边找鬼。 笑死,一个胖子当着我的面吹牛,可吹牛的内容都是我干的。 我是一名探鬼主播,决...
    沈念sama阅读 37,809评论 3 393
  • 文/苍兰香墨 我猛地睁开眼,长吁一口气:“原来是场噩梦啊……” “哼!你这毒妇竟也来了?” 一声冷哼从身侧响起,我...
    开封第一讲书人阅读 36,487评论 0 256
  • 序言:老挝万荣一对情侣失踪,失踪者是张志新(化名)和其女友刘颖,没想到半个月后,有当地人在树林里发现了一具尸体,经...
    沈念sama阅读 40,680评论 1 295
  • 正文 独居荒郊野岭守林人离奇死亡,尸身上长有42处带血的脓包…… 初始之章·张勋 以下内容为张勋视角 年9月15日...
    茶点故事阅读 35,499评论 2 318
  • 正文 我和宋清朗相恋三年,在试婚纱的时候发现自己被绿了。 大学时的朋友给我发了我未婚夫和他白月光在一起吃饭的照片。...
    茶点故事阅读 37,548评论 1 329
  • 序言:一个原本活蹦乱跳的男人离奇死亡,死状恐怖,灵堂内的尸体忽然破棺而出,到底是诈尸还是另有隐情,我是刑警宁泽,带...
    沈念sama阅读 33,268评论 4 318
  • 正文 年R本政府宣布,位于F岛的核电站,受9级特大地震影响,放射性物质发生泄漏。R本人自食恶果不足惜,却给世界环境...
    茶点故事阅读 38,815评论 3 304
  • 文/蒙蒙 一、第九天 我趴在偏房一处隐蔽的房顶上张望。 院中可真热闹,春花似锦、人声如沸。这庄子的主人今日做“春日...
    开封第一讲书人阅读 29,872评论 0 19
  • 文/苍兰香墨 我抬头看了看天上的太阳。三九已至,却和暖如春,着一层夹袄步出监牢的瞬间,已是汗流浃背。 一阵脚步声响...
    开封第一讲书人阅读 31,102评论 1 258
  • 我被黑心中介骗来泰国打工, 没想到刚下飞机就差点儿被人妖公主榨干…… 1. 我叫王不留,地道东北人。 一个月前我还...
    沈念sama阅读 42,683评论 2 348
  • 正文 我出身青楼,却偏偏与公主长得像,于是被迫代替她去往敌国和亲。 传闻我的和亲对象是个残疾皇子,可洞房花烛夜当晚...
    茶点故事阅读 42,253评论 2 341

推荐阅读更多精彩内容

  • OkHttp源码分析 在现在的Android开发中,请求网络获取数据基本上成了我们的标配。在早期的Android开...
    BlackFlag阅读 323评论 0 5
  • 主目录见:Android高级进阶知识(这是总目录索引) OkHttp的知识点实在是不少,优秀的思想也有很多,这里只...
    ZJ_Rocky阅读 2,287评论 2 6
  • 那么我今天给大家简单地讲一下Okhttp这款网络框架及其原理。它是如何请求数据,如何响应数据的 有什么优点?它的应...
    卓而不群_0137阅读 311评论 0 1
  • OkHttp源码分析-同步篇 很早就想拿okhttp开刀了,这次就记一次使用OKhttp的网络请求。首先需要说明的...
    埃赛尔阅读 963评论 1 2
  • 我一直很好奇一个人在因为被打扰睡觉而发脾气,之后又是怎样快速进入睡眠状态的。 我很难这样,因为会纠结别人的想法。 ...
    翻手光阴覆手金阅读 579评论 0 1