use of org.apache.http.nio.util.ContentOutputBuffer in project wso2-synapse by wso2.
the class SourceHandler method outputReady.
public void outputReady(NHttpServerConnection conn, ContentEncoder encoder) {
try {
ProtocolState protocolState = SourceContext.getState(conn);
// special case to handle WSDLs
if (protocolState == ProtocolState.WSDL_RESPONSE_DONE) {
// decrement request count for wsdl responses
metrics.requestServed();
// we need to shut down if the shutdown flag is set
HttpContext context = conn.getContext();
ContentOutputBuffer outBuf = (ContentOutputBuffer) context.getAttribute("synapse.response-source-buffer");
int bytesWritten = outBuf.produceContent(encoder);
if (metrics != null && bytesWritten > 0) {
metrics.incrementBytesSent(bytesWritten);
}
conn.requestInput();
if (outBuf instanceof SimpleOutputBuffer && !((SimpleOutputBuffer) outBuf).hasData()) {
sourceConfiguration.getSourceConnections().releaseConnection(conn);
}
endTransaction(conn);
return;
}
if (protocolState != ProtocolState.RESPONSE_HEAD && protocolState != ProtocolState.RESPONSE_BODY) {
log.warn("Illegal incoming connection state: " + protocolState + " . Possibly two send backs " + "are happening for the same request");
handleInvalidState(conn, "Trying to write response body");
endTransaction(conn);
return;
}
SourceRequest request = SourceContext.getRequest(conn);
SourceContext.updateState(conn, ProtocolState.RESPONSE_BODY);
SourceResponse response = SourceContext.getResponse(conn);
int bytesSent = -1;
boolean interceptionEnabled = false;
Boolean[] interceptorResults = new Boolean[noOfInterceptors];
if (interceptStream) {
int index = 0;
for (StreamInterceptor interceptor : streamInterceptors) {
interceptorResults[index] = interceptor.interceptSourceResponse((MessageContext) conn.getContext().getAttribute(PassThroughConstants.RESPONSE_MESSAGE_CONTEXT));
if (!interceptionEnabled && interceptorResults[index]) {
interceptionEnabled = true;
}
index++;
}
if (interceptionEnabled) {
ByteBuffer bytesWritten = response.copyAndWrite(conn, encoder);
if (bytesWritten != null) {
bytesSent = bytesWritten.remaining();
index = 0;
for (StreamInterceptor interceptor : streamInterceptors) {
if (interceptorResults[index]) {
interceptor.sourceResponse(bytesWritten.duplicate().asReadOnlyBuffer(), (MessageContext) conn.getContext().getAttribute(PassThroughConstants.RESPONSE_MESSAGE_CONTEXT));
}
index++;
}
}
} else {
bytesSent = response.write(conn, encoder);
}
} else {
bytesSent = response.write(conn, encoder);
}
if (encoder.isCompleted()) {
HttpContext context = conn.getContext();
long departure = System.currentTimeMillis();
context.setAttribute(PassThroughConstants.RES_TO_CLIENT_WRITE_END_TIME, departure);
context.setAttribute(PassThroughConstants.RES_DEPARTURE_TIME, departure);
if (sourceConfiguration.isCorrelationLoggingEnabled()) {
logCorrelationRoundTrip(context, request);
}
updateMetricsView(context);
}
endTransaction(conn);
metrics.incrementBytesSent(bytesSent);
} catch (IOException e) {
logIOException(conn, e);
informWriterError(conn);
SourceContext.updateState(conn, ProtocolState.CLOSING);
sourceConfiguration.getSourceConnections().shutDownConnection(conn, true);
}
}
use of org.apache.http.nio.util.ContentOutputBuffer in project wso2-synapse by wso2.
the class SourceHandler method getOutputStream.
/**
* Create synapse.response-source-buffer for GET and HEAD Http methods
* @param method Http Method
* @param request Source Request
* @return OutputStream
*/
public OutputStream getOutputStream(String method, SourceRequest request) {
OutputStream os = null;
if (HttpMethod.GET.equals(method) || HttpMethod.HEAD.equals(method)) {
HttpContext context = request.getConnection().getContext();
ContentOutputBuffer outputBuffer = new SimpleOutputBuffer(sourceConfiguration.getIOBufferSize(), new HeapByteBufferAllocator());
context.setAttribute("synapse.response-source-buffer", outputBuffer);
os = new ContentOutputStream(outputBuffer);
}
return os;
}
use of org.apache.http.nio.util.ContentOutputBuffer in project wso2-synapse by wso2.
the class ClientHandler method processConnection.
/**
* Process a new connection over an existing TCP connection or new
*
* @param conn HTTP connection to be processed
* @param axis2Req axis2 representation of the message in the connection
* @throws ConnectionClosedException if the connection is closed
*/
private void processConnection(final NHttpClientConnection conn, final Axis2HttpRequest axis2Req) throws ConnectionClosedException {
// record start time of request
ClientConnectionDebug cd = (ClientConnectionDebug) axis2Req.getMsgContext().getProperty(CLIENT_CONNECTION_DEBUG);
if (cd != null) {
cd.recordRequestStartTime(conn, axis2Req);
conn.getContext().setAttribute(CLIENT_CONNECTION_DEBUG, cd);
}
try {
// Reset connection metrics
conn.getMetrics().reset();
HttpContext context = conn.getContext();
ContentOutputBuffer outputBuffer = new NhttpSharedOutputBuffer(bufferSize, conn, allocator, socketTimeout);
axis2Req.setOutputBuffer(outputBuffer);
context.setAttribute(REQUEST_SOURCE_BUFFER, outputBuffer);
HttpRoute route = axis2Req.getRoute();
context.setAttribute(AXIS2_HTTP_REQUEST, axis2Req);
context.setAttribute(ExecutionContext.HTTP_CONNECTION, conn);
context.setAttribute(ExecutionContext.HTTP_TARGET_HOST, route.getTargetHost());
context.setAttribute(OUTGOING_MESSAGE_CONTEXT, axis2Req.getMsgContext());
context.setAttribute(NhttpConstants.PROXY_PROFILE_TARGET_HOST, axis2Req.getMsgContext().getProperty(NhttpConstants.PROXY_PROFILE_TARGET_HOST));
HttpRequest request = axis2Req.getRequest();
request.setParams(new DefaultedHttpParams(request.getParams(), this.params));
/*
* Remove Content-Length and Transfer-Encoding headers, if already present.
* */
request.removeHeaders(HTTP.TRANSFER_ENCODING);
request.removeHeaders(HTTP.CONTENT_LEN);
this.httpProcessor.process(request, context);
if (proxyauthenticator != null && route.getProxyHost() != null && !route.isTunnelled()) {
proxyauthenticator.authenticatePreemptively(request, context);
}
if (axis2Req.getTimeout() > 0) {
conn.setSocketTimeout(axis2Req.getTimeout());
}
context.setAttribute(NhttpConstants.ENDPOINT_PREFIX, axis2Req.getEndpointURLPrefix());
context.setAttribute(NhttpConstants.HTTP_REQ_METHOD, request.getRequestLine().getMethod());
context.setAttribute(ExecutionContext.HTTP_REQUEST, request);
setServerContextAttribute(NhttpConstants.REQ_DEPARTURE_TIME, System.currentTimeMillis(), conn);
setServerContextAttribute(NhttpConstants.REQ_TO_BACKEND_WRITE_START_TIME, System.currentTimeMillis(), conn);
conn.submitRequest(request);
} catch (ConnectionClosedException e) {
throw e;
} catch (IOException e) {
if (metrics != null) {
metrics.incrementFaultsSending();
}
handleException("I/O Error submitting request : " + e.getMessage(), e, conn);
} catch (HttpException e) {
if (metrics != null) {
metrics.incrementFaultsSending();
}
handleException("HTTP protocol error submitting request : " + e.getMessage(), e, conn);
} finally {
synchronized (axis2Req) {
axis2Req.setReadyToStream(true);
axis2Req.notifyAll();
}
}
}
use of org.apache.http.nio.util.ContentOutputBuffer in project wso2-synapse by wso2.
the class ClientHandler method outputReady.
/**
* Process ready output (i.e. write request to remote server)
*
* @param conn the connection being processed
* @param encoder the encoder in use
*/
public void outputReady(final NHttpClientConnection conn, final ContentEncoder encoder) {
HttpContext context = conn.getContext();
ContentOutputBuffer outBuf = (ContentOutputBuffer) context.getAttribute(REQUEST_SOURCE_BUFFER);
if (outBuf == null)
return;
try {
int bytesWritten = outBuf.produceContent(encoder);
if (metrics != null) {
if (bytesWritten > 0) {
if (metrics.getLevel() == MetricsCollector.LEVEL_FULL) {
metrics.incrementBytesSent(getMessageContext(conn), bytesWritten);
} else {
metrics.incrementBytesSent(bytesWritten);
}
}
if (encoder.isCompleted()) {
if (metrics.getLevel() == MetricsCollector.LEVEL_FULL) {
metrics.incrementMessagesSent(getMessageContext(conn));
} else {
metrics.incrementMessagesSent();
}
}
}
if (encoder.isCompleted()) {
ClientConnectionDebug ccd = (ClientConnectionDebug) context.getAttribute(CLIENT_CONNECTION_DEBUG);
if (ccd != null) {
ccd.recordRequestCompletionTime();
}
setServerContextAttribute(NhttpConstants.REQ_TO_BACKEND_WRITE_END_TIME, System.currentTimeMillis(), conn);
}
} catch (IOException e) {
if (metrics != null) {
if (metrics.getLevel() == MetricsCollector.LEVEL_FULL) {
metrics.incrementFaultsSending(NhttpConstants.SND_IO_ERROR_SENDING, getMessageContext(conn));
} else {
metrics.incrementFaultsSending();
}
}
handleException("I/O Error at outputReady : " + e.getMessage(), e, conn);
}
}
use of org.apache.http.nio.util.ContentOutputBuffer in project wso2-synapse by wso2.
the class ClientHandler method responseReceived.
/**
* Process a response received for the request sent out
*
* @param conn the connection being processed
*/
public void responseReceived(final NHttpClientConnection conn) {
setServerContextAttribute(NhttpConstants.RES_FROM_BACKEND_READ_START_TIME, System.currentTimeMillis(), conn);
HttpContext context = conn.getContext();
// set the current message size to zero
if (isMessageSizeValidationEnabled) {
context.setAttribute(NhttpConstants.MESSAGE_SIZE_VALIDATION_SUM, 0);
}
HttpResponse response = conn.getHttpResponse();
ProxyTunnelHandler tunnelHandler = (ProxyTunnelHandler) context.getAttribute(TUNNEL_HANDLER);
if (tunnelHandler != null && !tunnelHandler.isCompleted()) {
context.removeAttribute(TUNNEL_HANDLER);
tunnelHandler.handleResponse(response, conn);
if (tunnelHandler.isSuccessful()) {
log.debug(conn + ": Tunnel established");
conn.resetInput();
conn.requestOutput();
return;
} else {
Axis2HttpRequest axis2Req = (Axis2HttpRequest) context.getAttribute(ATTACHMENT_KEY);
context.setAttribute(AXIS2_HTTP_REQUEST, axis2Req);
context.setAttribute(OUTGOING_MESSAGE_CONTEXT, axis2Req.getMsgContext());
ContentOutputBuffer outputBuffer = new NhttpSharedOutputBuffer(bufferSize, conn, allocator, socketTimeout);
axis2Req.setOutputBuffer(outputBuffer);
context.setAttribute(REQUEST_SOURCE_BUFFER, outputBuffer);
context.setAttribute(NhttpConstants.DISCARD_ON_COMPLETE, Boolean.TRUE);
}
}
setServerContextAttribute(NhttpConstants.RES_HEADER_ARRIVAL_TIME, System.currentTimeMillis(), conn);
if (response.getStatusLine().getStatusCode() == HttpStatus.SC_CONTINUE) {
if (log.isDebugEnabled()) {
log.debug(conn + ": Received a 100 Continue response");
}
// and wait for the response
return;
}
ClientConnectionDebug ccd = (ClientConnectionDebug) conn.getContext().getAttribute(CLIENT_CONNECTION_DEBUG);
if (ccd != null) {
ccd.recordResponseStartTime(response.getStatusLine().toString());
}
// Have we sent out our request fully in the first place? if not, forget about it now..
Axis2HttpRequest req = (Axis2HttpRequest) conn.getContext().getAttribute(AXIS2_HTTP_REQUEST);
if (req != null) {
req.setCompleted(true);
if (log.isDebugEnabled()) {
log.debug(conn + ": Response Received for Request : " + req);
}
if (!req.isSendingCompleted()) {
req.getMsgContext().setProperty(NhttpConstants.ERROR_CODE, NhttpConstants.SEND_ABORT);
NhttpSharedOutputBuffer outputBuffer = (NhttpSharedOutputBuffer) conn.getContext().getAttribute(REQUEST_SOURCE_BUFFER);
if (outputBuffer != null) {
outputBuffer.shutdown();
}
if (log.isDebugEnabled()) {
log.debug(conn + ": Remote server aborted request being sent and replied : " + conn + " for request : " + conn.getContext().getAttribute(NhttpConstants.HTTP_REQ_METHOD));
}
context.setAttribute(NhttpConstants.DISCARD_ON_COMPLETE, Boolean.TRUE);
if (metrics != null) {
metrics.incrementFaultsSending(NhttpConstants.SEND_ABORT, req.getMsgContext());
}
}
}
switch(response.getStatusLine().getStatusCode()) {
case HttpStatus.SC_ACCEPTED:
{
if (log.isDebugEnabled()) {
log.debug(conn + ": Received a 202 Accepted response");
}
// Process response body if Content-Type header is present in the response
// If Content-Type header is null, We will ignore entity body
Header contentType = response.getFirstHeader(HTTP.CONTENT_TYPE);
if (contentType != null) {
processResponse(conn, context, response);
return;
}
// sometimes, some http clients sends an "\r\n" as the content body with a
// HTTP 202 OK.. we will just get it into this temp buffer and ignore it..
ContentInputBuffer inputBuffer = new SharedInputBuffer(8, conn, allocator);
context.setAttribute(RESPONSE_SINK_BUFFER, inputBuffer);
// create a dummy message with an empty SOAP envelope and a property
// NhttpConstants.SC_ACCEPTED set to Boolean.TRUE to indicate this is a
// placeholder message for the transport to send a HTTP 202 to the
// client. Should / would be ignored by any transport other than
// nhttp. For example, JMS would not send a reply message for one-way
// operations.
MessageContext outMsgCtx = (MessageContext) context.getAttribute(OUTGOING_MESSAGE_CONTEXT);
MessageReceiver mr = outMsgCtx.getAxisOperation().getMessageReceiver();
// 202 Accepted message
if (!outMsgCtx.isPropertyTrue(NhttpConstants.IGNORE_SC_ACCEPTED)) {
try {
MessageContext responseMsgCtx = outMsgCtx.getOperationContext().getMessageContext(WSDL2Constants.MESSAGE_LABEL_IN);
if (responseMsgCtx == null || outMsgCtx.getOptions().isUseSeparateListener() || outMsgCtx.getOperationContext().isComplete()) {
if (responseMsgCtx != null && responseMsgCtx.getProperty("synapse.send") == null) {
return;
}
} else if (responseMsgCtx == null || outMsgCtx.getOptions().isUseSeparateListener()) {
// Since we need to notify the SynapseCallback receiver to remove the
// call backs registered we set a custom property
setHeaders(context, response, outMsgCtx, responseMsgCtx);
outMsgCtx.setProperty(NhttpConstants.HTTP_202_RECEIVED, "true");
mr.receive(outMsgCtx);
return;
}
if (responseMsgCtx == null) {
return;
}
setHeaders(context, response, outMsgCtx, responseMsgCtx);
responseMsgCtx.setServerSide(true);
responseMsgCtx.setDoingREST(outMsgCtx.isDoingREST());
responseMsgCtx.setProperty(MessageContext.TRANSPORT_IN, outMsgCtx.getProperty(MessageContext.TRANSPORT_IN));
responseMsgCtx.setTransportIn(outMsgCtx.getTransportIn());
responseMsgCtx.setTransportOut(outMsgCtx.getTransportOut());
responseMsgCtx.setAxisMessage(outMsgCtx.getAxisOperation().getMessage(WSDLConstants.MESSAGE_LABEL_IN_VALUE));
responseMsgCtx.setOperationContext(outMsgCtx.getOperationContext());
responseMsgCtx.setConfigurationContext(outMsgCtx.getConfigurationContext());
responseMsgCtx.setTo(null);
if (!outMsgCtx.isDoingREST() && !outMsgCtx.isSOAP11()) {
responseMsgCtx.setEnvelope(new SOAP12Factory().getDefaultEnvelope());
} else {
responseMsgCtx.setEnvelope(new SOAP11Factory().getDefaultEnvelope());
}
responseMsgCtx.setProperty(AddressingConstants.DISABLE_ADDRESSING_FOR_OUT_MESSAGES, Boolean.TRUE);
responseMsgCtx.setProperty(NhttpConstants.SC_ACCEPTED, Boolean.TRUE);
int statusCode = response.getStatusLine().getStatusCode();
responseMsgCtx.setProperty(NhttpConstants.HTTP_SC, statusCode);
mr.receive(responseMsgCtx);
} catch (org.apache.axis2.AxisFault af) {
log.debug(conn + ": Unable to report back " + "202 Accepted state to the message receiver");
}
}
return;
}
case HttpStatus.SC_OK:
{
processResponse(conn, context, response);
return;
}
case HttpStatus.SC_INTERNAL_SERVER_ERROR:
{
if (warnOnHttp500(response)) {
log.warn(getErrorMessage("Received an internal server error : " + response.getStatusLine().getReasonPhrase(), conn));
}
processResponse(conn, context, response);
return;
}
default:
{
if (log.isDebugEnabled()) {
log.debug(conn + ": " + getErrorMessage("HTTP status code received : " + response.getStatusLine().getStatusCode() + " :: " + response.getStatusLine().getReasonPhrase(), conn));
}
Header contentType = response.getFirstHeader(HTTP.CONTENT_TYPE);
if (contentType != null) {
if ((contentType.getValue().indexOf(SOAP11Constants.SOAP_11_CONTENT_TYPE) >= 0) || contentType.getValue().indexOf(SOAP12Constants.SOAP_12_CONTENT_TYPE) >= 0) {
if (log.isDebugEnabled()) {
log.debug(conn + ": Received an unexpected response with a SOAP payload");
}
} else if (contentType.getValue().indexOf("html") == -1) {
if (log.isDebugEnabled()) {
log.debug(conn + ": Received an unexpected response with a POX/REST payload");
}
} else {
log.warn(getErrorMessage("Received an unexpected response - " + "of content type : " + contentType.getValue() + " and status code : " + response.getStatusLine().getStatusCode() + " with reason : " + response.getStatusLine().getReasonPhrase(), conn));
}
} else {
if (log.isDebugEnabled()) {
log.debug(conn + ": " + getErrorMessage("Received a response - " + "without a content type with status code : " + response.getStatusLine().getStatusCode() + " and reason : " + response.getStatusLine().getReasonPhrase(), conn));
}
}
processResponse(conn, context, response);
}
}
}
Aggregations