package jdk.internal.net.http;
import java.io.EOFException;
import java.lang.System.Logger.Level;
import java.nio.ByteBuffer;
import java.util.List;
import java.util.concurrent.CompletableFuture;
import java.util.concurrent.CompletionStage;
import java.util.concurrent.Executor;
import java.util.concurrent.Flow;
import java.util.concurrent.atomic.AtomicBoolean;
import java.util.concurrent.atomic.AtomicLong;
import java.util.function.Consumer;
import java.util.function.Function;
import java.net.http.HttpHeaders;
import java.net.http.HttpResponse;
import jdk.internal.net.http.ResponseContent.BodyParser;
import jdk.internal.net.http.ResponseContent.UnknownLengthBodyParser;
import jdk.internal.net.http.ResponseSubscribers.TrustedSubscriber;
import jdk.internal.net.http.common.Log;
import jdk.internal.net.http.common.Logger;
import jdk.internal.net.http.common.MinimalFuture;
import jdk.internal.net.http.common.Utils;
import static java.net.http.HttpClient.Version.HTTP_1_1;
import static java.net.http.HttpResponse.BodySubscribers.discarding;
import static jdk.internal.net.http.common.Utils.wrapWithExtraDetail;
import static jdk.internal.net.http.RedirectFilter.HTTP_NOT_MODIFIED;
class Http1Response<T> {
private volatile ResponseContent content;
private final HttpRequestImpl request;
private Response response;
private final HttpConnection connection;
private HttpHeaders ;
private int responseCode;
private final Http1Exchange<T> exchange;
private boolean return2Cache;
private final HeadersReader ;
private final BodyReader bodyReader;
private final Http1AsyncReceiver asyncReceiver;
private volatile EOFException eof;
private volatile BodyParser bodyParser;
private final static int MAX_IGNORE = 1024;
static enum State {INITIAL, READING_HEADERS, READING_BODY, DONE}
private volatile State readProgress = State.INITIAL;
final Logger debug = Utils.getDebugLogger(this::dbgString, Utils.DEBUG);
final static AtomicLong responseCount = new AtomicLong();
final long id = responseCount.incrementAndGet();
private Http1HeaderParser hd;
Http1Response(HttpConnection conn,
Http1Exchange<T> exchange,
Http1AsyncReceiver asyncReceiver) {
this.readProgress = State.INITIAL;
this.request = exchange.request();
this.exchange = exchange;
this.connection = conn;
this.asyncReceiver = asyncReceiver;
headersReader = new HeadersReader(this::advance);
bodyReader = new BodyReader(this::advance);
hd = new Http1HeaderParser();
readProgress = State.READING_HEADERS;
headersReader.start(hd);
asyncReceiver.subscribe(headersReader);
}
String dbgTag;
private String dbgString() {
String dbg = dbgTag;
if (dbg == null) {
String cdbg = connection.dbgTag;
if (cdbg != null) {
dbgTag = dbg = "Http1Response(id=" + id + ", " + cdbg + ")";
} else {
dbg = "Http1Response(id=" + id + ")";
}
}
return dbg;
}
private final class ClientRefCountTracker {
final HttpClientImpl client = connection.client();
byte state;
public synchronized void acquire() {
if (state == 0) {
if (debug.on())
debug.log("Operation started: incrementing ref count for %s", client);
client.reference();
state = 0x01;
} else {
if (debug.on())
debug.log("Operation ref count for %s is already %s",
client, ((state & 0x2) == 0x2) ? "released." : "incremented!" );
assert (state & 0x01) == 0 : "reference count already incremented";
}
}
public synchronized void tryRelease() {
if (state == 0x01) {
if (debug.on())
debug.log("Operation finished: decrementing ref count for %s", client);
client.unreference();
} else if (state == 0) {
if (debug.on())
debug.log("Operation finished: releasing ref count for %s", client);
} else if ((state & 0x02) == 0x02) {
if (debug.on())
debug.log("ref count for %s already released", client);
}
state |= 0x02;
}
}
private volatile boolean firstTimeAround = true;
public CompletableFuture<Response> (Executor executor) {
if (debug.on())
debug.log("Reading Headers: (remaining: "
+ asyncReceiver.remaining() +") " + readProgress);
if (firstTimeAround) {
if (debug.on()) debug.log("First time around");
firstTimeAround = false;
} else {
asyncReceiver.unsubscribe(bodyReader);
bodyReader.reset();
hd = new Http1HeaderParser();
readProgress = State.READING_HEADERS;
headersReader.reset();
headersReader.start(hd);
asyncReceiver.subscribe(headersReader);
}
CompletableFuture<State> cf = headersReader.completion();
assert cf != null : "parsing not started";
if (debug.on()) {
debug.log("headersReader is %s",
cf == null ? "not yet started"
: cf.isDone() ? "already completed"
: "not yet completed");
}
Function<State, Response> lambda = (State completed) -> {
assert completed == State.READING_HEADERS;
if (debug.on())
debug.log("Reading Headers: creating Response object;"
+ " state is now " + readProgress);
asyncReceiver.unsubscribe(headersReader);
responseCode = hd.responseCode();
headers = hd.headers();
response = new Response(request,
exchange.getExchange(),
headers,
connection,
responseCode,
HTTP_1_1);
if (Log.headers()) {
StringBuilder sb = new StringBuilder("RESPONSE HEADERS:\n");
Log.dumpHeaders(sb, " ", headers);
Log.logHeaders(sb.toString());
}
return response;
};
if (executor != null) {
return cf.thenApplyAsync(lambda, executor);
} else {
return cf.thenApply(lambda);
}
}
private boolean finished;
synchronized void completed() {
finished = true;
}
synchronized boolean finished() {
return finished;
}
long fixupContentLen(long clen) {
if (request.method().equalsIgnoreCase("HEAD") || responseCode == HTTP_NOT_MODIFIED) {
return 0L;
}
if (clen == -1L) {
if (headers.firstValue("Transfer-encoding").orElse("")
.equalsIgnoreCase("chunked")) {
return -1L;
}
if (responseCode == 101) {
return 0L;
}
return -2L;
}
return clen;
}
public CompletableFuture<Void> ignoreBody(Executor executor) {
int clen = (int)headers.firstValueAsLong("Content-Length").orElse(-1);
if (clen == -1 || clen > MAX_IGNORE) {
connection.close();
return MinimalFuture.completedFuture(null);
} else {
return readBody(discarding(), !request.isWebSocket(), executor);
}
}
public void nullBody(HttpResponse<T> resp, Throwable t) {
if (t != null) connection.close();
else {
return2Cache = !request.isWebSocket();
onFinished();
}
}
static final Flow.Subscription NOP = new Flow.Subscription() {
@Override
public void request(long n) { }
public void cancel() { }
};
final static class Http1BodySubscriber<U> implements TrustedSubscriber<U> {
final HttpResponse.BodySubscriber<U> userSubscriber;
final AtomicBoolean completed = new AtomicBoolean();
volatile Throwable withError;
volatile boolean subscribed;
Http1BodySubscriber(HttpResponse.BodySubscriber<U> userSubscriber) {
this.userSubscriber = userSubscriber;
}
@Override
public boolean needsExecutor() {
return TrustedSubscriber.needsExecutor(userSubscriber);
}
private void propagateError(Throwable t) {
assert t != null;
try {
if (subscribed == false) {
subscribed = true;
userSubscriber.onSubscribe(NOP);
}
} finally {
userSubscriber.onError(t);
}
}
private void complete(Throwable t) {
if (completed.compareAndSet(false, true)) {
t = withError = Utils.getCompletionCause(t);
if (t == null) {
assert subscribed;
try {
userSubscriber.onComplete();
} catch (Throwable x) {
propagateError(t = withError = Utils.getCompletionCause(x));
}
} else {
propagateError(t);
}
}
}
@Override
public CompletionStage<U> getBody() {
return userSubscriber.getBody();
}
@Override
public void onSubscribe(Flow.Subscription subscription) {
if (!subscribed) {
subscribed = true;
userSubscriber.onSubscribe(subscription);
} else {
assert completed.get();
}
}
@Override
public void onNext(List<ByteBuffer> item) {
assert !completed.get();
userSubscriber.onNext(item);
}
@Override
public void onError(Throwable throwable) {
complete(throwable);
}
@Override
public void onComplete() {
complete(null);
}
}
public <U> CompletableFuture<U> readBody(HttpResponse.BodySubscriber<U> p,
boolean return2Cache,
Executor executor) {
if (debug.on()) {
debug.log("readBody: return2Cache: " + return2Cache);
if (request.isWebSocket() && return2Cache && connection != null) {
debug.log("websocket connection will be returned to cache: "
+ connection.getClass() + "/" + connection );
}
}
assert !return2Cache || !request.isWebSocket();
this.return2Cache = return2Cache;
final Http1BodySubscriber<U> subscriber = new Http1BodySubscriber<>(p);
final CompletableFuture<U> cf = new MinimalFuture<>();
long clen0 = headers.firstValueAsLong("Content-Length").orElse(-1L);
final long clen = fixupContentLen(clen0);
asyncReceiver.unsubscribe(headersReader);
headersReader.reset();
ClientRefCountTracker refCountTracker = new ClientRefCountTracker();
connection.client().reference();
executor.execute(() -> {
try {
content = new ResponseContent(
connection, clen, headers, subscriber,
this::onFinished
);
if (cf.isCompletedExceptionally()) {
connection.close();
return;
}
refCountTracker.acquire();
bodyParser = content.getBodyParser(
(t) -> {
try {
if (t != null) {
try {
subscriber.onError(t);
} finally {
cf.completeExceptionally(t);
}
}
} finally {
bodyReader.onComplete(t);
if (t != null) {
connection.close();
}
}
});
bodyReader.start(bodyParser);
CompletableFuture<State> bodyReaderCF = bodyReader.completion();
asyncReceiver.subscribe(bodyReader);
assert bodyReaderCF != null : "parsing not started";
CompletableFuture<?> trailingOp = bodyReaderCF.whenComplete((s,t) -> {
t = Utils.getCompletionCause(t);
try {
if (t == null) {
if (debug.on()) debug.log("Finished reading body: " + s);
assert s == State.READING_BODY;
}
if (t != null) {
subscriber.onError(t);
cf.completeExceptionally(t);
}
} catch (Throwable x) {
asyncReceiver.onReadError(x);
} finally {
refCountTracker.tryRelease();
}
});
connection.addTrailingOperation(trailingOp);
} catch (Throwable t) {
if (debug.on()) debug.log("Failed reading body: " + t);
try {
subscriber.onError(t);
cf.completeExceptionally(t);
} finally {
asyncReceiver.onReadError(t);
}
} finally {
connection.client().unreference();
}
});
ResponseSubscribers.getBodyAsync(executor, p, cf, (t) -> {
cf.completeExceptionally(t);
asyncReceiver.setRetryOnError(false);
asyncReceiver.onReadError(t);
});
return cf.whenComplete((s,t) -> {
if (t != null) {
refCountTracker.tryRelease();
}
});
}
private void onFinished() {
asyncReceiver.clear();
if (return2Cache) {
Log.logTrace("Attempting to return connection to the pool: {0}", connection);
if (debug.on())
debug.log(connection.getConnectionFlow() + ": return to HTTP/1.1 pool");
connection.closeOrReturnToCache(eof == null ? headers : null);
}
}
HttpHeaders () {
return headers;
}
int responseCode() {
return responseCode;
}
void onReadError(Throwable t) {
Log.logError(t);
Receiver<?> receiver = receiver(readProgress);
if (t instanceof EOFException) {
debug.log(Level.DEBUG, "onReadError: received EOF");
eof = (EOFException) t;
}
CompletableFuture<?> cf = receiver == null ? null : receiver.completion();
debug.log(Level.DEBUG, () -> "onReadError: cf is "
+ (cf == null ? "null"
: (cf.isDone() ? "already completed"
: "not yet completed")));
if (cf != null) {
cf.completeExceptionally(t);
} else {
debug.log(Level.DEBUG, "onReadError", t);
}
debug.log(Level.DEBUG, () -> "closing connection: cause is " + t);
connection.close();
}
private State advance(State previous) {
assert readProgress == previous;
switch(previous) {
case READING_HEADERS:
asyncReceiver.unsubscribe(headersReader);
return readProgress = State.READING_BODY;
case READING_BODY:
asyncReceiver.unsubscribe(bodyReader);
return readProgress = State.DONE;
default:
throw new InternalError("can't advance from " + previous);
}
}
Receiver<?> receiver(State state) {
return switch (state) {
case READING_HEADERS -> headersReader;
case READING_BODY -> bodyReader;
default -> null;
};
}
static abstract class Receiver<T>
implements Http1AsyncReceiver.Http1AsyncDelegate {
abstract void start(T parser);
abstract CompletableFuture<State> completion();
public abstract boolean tryAsyncReceive(ByteBuffer buffer);
public abstract void onReadError(Throwable t);
abstract void handle(ByteBuffer buf, T parser,
CompletableFuture<State> cf);
abstract void reset();
final boolean accept(ByteBuffer buf, T parser,
CompletableFuture<State> cf) {
if (cf == null || parser == null || cf.isDone()) return false;
handle(buf, parser, cf);
return !cf.isDone();
}
public abstract void onSubscribe(AbstractSubscription s);
public abstract AbstractSubscription subscription();
}
final class extends Receiver<Http1HeaderParser> {
final Consumer<State> ;
volatile Http1HeaderParser ;
volatile CompletableFuture<State> ;
volatile long ;
volatile AbstractSubscription ;
(Consumer<State> onComplete) {
this.onComplete = onComplete;
}
@Override
public AbstractSubscription () {
return subscription;
}
@Override
public void (AbstractSubscription s) {
this.subscription = s;
s.request(1);
}
@Override
void () {
cf = null;
parser = null;
count = 0;
subscription = null;
}
@Override
final void (Http1HeaderParser hp) {
count = 0;
cf = new MinimalFuture<>();
parser = hp;
}
@Override
CompletableFuture<State> () {
return cf;
}
@Override
public final boolean (ByteBuffer ref) {
boolean hasDemand = subscription.demand().tryDecrement();
assert hasDemand;
boolean needsMore = accept(ref, parser, cf);
if (needsMore) subscription.request(1);
return needsMore;
}
@Override
public final void (Throwable t) {
t = wrapWithExtraDetail(t, parser::currentStateMessage);
Http1Response.this.onReadError(t);
}
@Override
final void handle(ByteBuffer b,
Http1HeaderParser parser,
CompletableFuture<State> cf) {
assert cf != null : "parsing not started";
assert parser != null : "no parser";
try {
count += b.remaining();
if (debug.on())
debug.log("Sending " + b.remaining() + "/" + b.capacity()
+ " bytes to header parser");
if (parser.parse(b)) {
count -= b.remaining();
if (debug.on())
debug.log("Parsing headers completed. bytes=" + count);
onComplete.accept(State.READING_HEADERS);
cf.complete(State.READING_HEADERS);
}
} catch (Throwable t) {
if (debug.on())
debug.log("Header parser failed to handle buffer: " + t);
cf.completeExceptionally(t);
}
}
@Override
public void (Throwable error) {
if (error != null) {
CompletableFuture<State> cf = this.cf;
if (cf != null) {
if (debug.on())
debug.log("close: completing header parser CF with " + error);
cf.completeExceptionally(error);
}
}
}
}
final class BodyReader extends Receiver<BodyParser> {
final Consumer<State> onComplete;
volatile BodyParser parser;
volatile CompletableFuture<State> cf;
volatile AbstractSubscription subscription;
BodyReader(Consumer<State> onComplete) {
this.onComplete = onComplete;
}
@Override
void reset() {
parser = null;
cf = null;
subscription = null;
}
@Override
final void start(BodyParser parser) {
cf = new MinimalFuture<>();
this.parser = parser;
}
@Override
CompletableFuture<State> completion() {
return cf;
}
@Override
public final boolean tryAsyncReceive(ByteBuffer b) {
return accept(b, parser, cf);
}
@Override
public final void onReadError(Throwable t) {
if (t instanceof EOFException && bodyParser != null &&
bodyParser instanceof UnknownLengthBodyParser) {
((UnknownLengthBodyParser)bodyParser).complete();
return;
}
t = wrapWithExtraDetail(t, parser::currentStateMessage);
Http1Response.this.onReadError(t);
}
@Override
public AbstractSubscription subscription() {
return subscription;
}
@Override
public void onSubscribe(AbstractSubscription s) {
this.subscription = s;
try {
parser.onSubscribe(s);
} catch (Throwable t) {
cf.completeExceptionally(t);
throw t;
}
}
@Override
final void handle(ByteBuffer b,
BodyParser parser,
CompletableFuture<State> cf) {
assert cf != null : "parsing not started";
assert parser != null : "no parser";
try {
if (debug.on())
debug.log("Sending " + b.remaining() + "/" + b.capacity()
+ " bytes to body parser");
parser.accept(b);
} catch (Throwable t) {
if (debug.on())
debug.log("Body parser failed to handle buffer: " + t);
if (!cf.isDone()) {
cf.completeExceptionally(t);
}
}
}
final void onComplete(Throwable closedExceptionally) {
if (cf.isDone()) return;
if (closedExceptionally != null) {
cf.completeExceptionally(closedExceptionally);
} else {
onComplete.accept(State.READING_BODY);
cf.complete(State.READING_BODY);
}
}
@Override
public final void close(Throwable error) {
CompletableFuture<State> cf = this.cf;
if (cf != null && !cf.isDone()) {
if (error != null) {
if (debug.on())
debug.log("close: completing body parser CF with " + error);
cf.completeExceptionally(error);
} else {
if (debug.on())
debug.log("close: completing body parser CF");
cf.complete(State.READING_BODY);
}
}
}
@Override
public String toString() {
return super.toString() + "/parser=" + String.valueOf(parser);
}
}
}