Search in sources :

Example 1 with Command

use of org.apache.hc.core5.reactor.Command in project httpcomponents-core by apache.

the class ClientSessionEndpoint method execute.

public void execute(final AsyncClientExchangeHandler exchangeHandler, final HandlerFactory<AsyncPushConsumer> pushHandlerFactory, final HttpContext context) {
    Asserts.check(!closed.get(), "Connection is already closed");
    final Command executionCommand = new RequestExecutionCommand(exchangeHandler, pushHandlerFactory, null, context);
    ioSession.enqueue(executionCommand, Command.Priority.NORMAL);
    if (!ioSession.isOpen()) {
        exchangeHandler.failed(new ConnectionClosedException());
    }
}
Also used : ShutdownCommand(org.apache.hc.core5.http.nio.command.ShutdownCommand) Command(org.apache.hc.core5.reactor.Command) RequestExecutionCommand(org.apache.hc.core5.http.nio.command.RequestExecutionCommand) ConnectionClosedException(org.apache.hc.core5.http.ConnectionClosedException) RequestExecutionCommand(org.apache.hc.core5.http.nio.command.RequestExecutionCommand)

Example 2 with Command

use of org.apache.hc.core5.reactor.Command in project httpcomponents-core by apache.

the class AbstractH2StreamMultiplexer method processPendingCommands.

private void processPendingCommands() throws IOException, HttpException {
    while (streamMap.size() < remoteConfig.getMaxConcurrentStreams()) {
        final Command command = ioSession.poll();
        if (command == null) {
            break;
        }
        if (command instanceof ShutdownCommand) {
            final ShutdownCommand shutdownCommand = (ShutdownCommand) command;
            if (shutdownCommand.getType() == CloseMode.IMMEDIATE) {
                for (final Iterator<Map.Entry<Integer, H2Stream>> it = streamMap.entrySet().iterator(); it.hasNext(); ) {
                    final Map.Entry<Integer, H2Stream> entry = it.next();
                    final H2Stream stream = entry.getValue();
                    stream.cancel();
                }
                streamMap.clear();
                connState = ConnectionHandshake.SHUTDOWN;
            } else {
                if (connState.compareTo(ConnectionHandshake.ACTIVE) <= 0) {
                    final RawFrame goAway = frameFactory.createGoAway(processedRemoteStreamId, H2Error.NO_ERROR, "Graceful shutdown");
                    commitFrame(goAway);
                    connState = streamMap.isEmpty() ? ConnectionHandshake.SHUTDOWN : ConnectionHandshake.GRACEFUL_SHUTDOWN;
                }
            }
            break;
        } else if (command instanceof PingCommand) {
            final PingCommand pingCommand = (PingCommand) command;
            final AsyncPingHandler handler = pingCommand.getHandler();
            pingHandlers.add(handler);
            final RawFrame ping = frameFactory.createPing(handler.getData());
            commitFrame(ping);
        } else if (command instanceof ExecutableCommand) {
            final int streamId = generateStreamId();
            final H2StreamChannelImpl channel = new H2StreamChannelImpl(streamId, true, initInputWinSize, initOutputWinSize);
            final ExecutableCommand executableCommand = (ExecutableCommand) command;
            final H2StreamHandler streamHandler = createLocallyInitiatedStream(executableCommand, channel, httpProcessor, connMetrics);
            final H2Stream stream = new H2Stream(channel, streamHandler, false);
            streamMap.put(streamId, stream);
            if (streamListener != null) {
                final int initInputWindow = stream.getInputWindow().get();
                streamListener.onInputFlowControl(this, streamId, initInputWindow, initInputWindow);
                final int initOutputWindow = stream.getOutputWindow().get();
                streamListener.onOutputFlowControl(this, streamId, initOutputWindow, initOutputWindow);
            }
            if (stream.isOutputReady()) {
                stream.produceOutput();
            }
            final CancellableDependency cancellableDependency = executableCommand.getCancellableDependency();
            if (cancellableDependency != null) {
                cancellableDependency.setDependency(stream::abort);
            }
            if (!outputQueue.isEmpty()) {
                return;
            }
        }
    }
}
Also used : ShutdownCommand(org.apache.hc.core5.http.nio.command.ShutdownCommand) PingCommand(org.apache.hc.core5.http2.nio.command.PingCommand) CancellableDependency(org.apache.hc.core5.concurrent.CancellableDependency) AtomicInteger(java.util.concurrent.atomic.AtomicInteger) PingCommand(org.apache.hc.core5.http2.nio.command.PingCommand) ExecutableCommand(org.apache.hc.core5.http.nio.command.ExecutableCommand) Command(org.apache.hc.core5.reactor.Command) ShutdownCommand(org.apache.hc.core5.http.nio.command.ShutdownCommand) AsyncPingHandler(org.apache.hc.core5.http2.nio.AsyncPingHandler) RawFrame(org.apache.hc.core5.http2.frame.RawFrame) ExecutableCommand(org.apache.hc.core5.http.nio.command.ExecutableCommand) Map(java.util.Map) ConcurrentHashMap(java.util.concurrent.ConcurrentHashMap)

Example 3 with Command

use of org.apache.hc.core5.reactor.Command in project httpcomponents-core by apache.

the class ClientH2StreamMultiplexer method createLocallyInitiatedStream.

@Override
H2StreamHandler createLocallyInitiatedStream(final ExecutableCommand command, final H2StreamChannel channel, final HttpProcessor httpProcessor, final BasicHttpConnectionMetrics connMetrics) throws IOException {
    if (command instanceof RequestExecutionCommand) {
        final RequestExecutionCommand executionCommand = (RequestExecutionCommand) command;
        final AsyncClientExchangeHandler exchangeHandler = executionCommand.getExchangeHandler();
        final HandlerFactory<AsyncPushConsumer> pushHandlerFactory = executionCommand.getPushHandlerFactory();
        final HttpCoreContext context = HttpCoreContext.adapt(executionCommand.getContext());
        context.setAttribute(HttpCoreContext.SSL_SESSION, getSSLSession());
        context.setAttribute(HttpCoreContext.CONNECTION_ENDPOINT, getEndpointDetails());
        return new ClientH2StreamHandler(channel, httpProcessor, connMetrics, exchangeHandler, pushHandlerFactory != null ? pushHandlerFactory : this.pushHandlerFactory, context);
    }
    throw new H2ConnectionException(H2Error.INTERNAL_ERROR, "Unexpected executable command");
}
Also used : AsyncPushConsumer(org.apache.hc.core5.http.nio.AsyncPushConsumer) AsyncClientExchangeHandler(org.apache.hc.core5.http.nio.AsyncClientExchangeHandler) HttpCoreContext(org.apache.hc.core5.http.protocol.HttpCoreContext) H2ConnectionException(org.apache.hc.core5.http2.H2ConnectionException) RequestExecutionCommand(org.apache.hc.core5.http.nio.command.RequestExecutionCommand)

Example 4 with Command

use of org.apache.hc.core5.reactor.Command in project httpcomponents-core by apache.

the class AbstractHttp1StreamDuplexer method processCommands.

private void processCommands() throws HttpException, IOException {
    for (; ; ) {
        final Command command = ioSession.poll();
        if (command == null) {
            return;
        }
        if (command instanceof ShutdownCommand) {
            final ShutdownCommand shutdownCommand = (ShutdownCommand) command;
            requestShutdown(shutdownCommand.getType());
        } else if (command instanceof RequestExecutionCommand) {
            if (connState.compareTo(ConnectionState.GRACEFUL_SHUTDOWN) >= 0) {
                command.cancel();
            } else {
                execute((RequestExecutionCommand) command);
                return;
            }
        } else {
            throw new HttpException("Unexpected command: " + command.getClass());
        }
    }
}
Also used : Command(org.apache.hc.core5.reactor.Command) ShutdownCommand(org.apache.hc.core5.http.nio.command.ShutdownCommand) RequestExecutionCommand(org.apache.hc.core5.http.nio.command.RequestExecutionCommand) HttpException(org.apache.hc.core5.http.HttpException) RequestExecutionCommand(org.apache.hc.core5.http.nio.command.RequestExecutionCommand) ShutdownCommand(org.apache.hc.core5.http.nio.command.ShutdownCommand)

Example 5 with Command

use of org.apache.hc.core5.reactor.Command in project httpcomponents-core by apache.

the class InternalDataChannel method enqueue.

@Override
public void enqueue(final Command command, final Command.Priority priority) {
    final IOSession currentSession = currentSessionRef.get();
    currentSession.enqueue(command, priority);
}
Also used : SSLIOSession(org.apache.hc.core5.reactor.ssl.SSLIOSession)

Aggregations

Command (org.apache.hc.core5.reactor.Command)9 ShutdownCommand (org.apache.hc.core5.http.nio.command.ShutdownCommand)5 IOException (java.io.IOException)4 Map (java.util.Map)4 ConnectionClosedException (org.apache.hc.core5.http.ConnectionClosedException)4 RequestExecutionCommand (org.apache.hc.core5.http.nio.command.RequestExecutionCommand)4 ConcurrentHashMap (java.util.concurrent.ConcurrentHashMap)3 AtomicInteger (java.util.concurrent.atomic.AtomicInteger)3 File (java.io.File)2 URI (java.net.URI)2 HttpPost (org.apache.hc.client5.http.classic.methods.HttpPost)2 HttpRequest (org.apache.hc.core5.http.HttpRequest)2 ProtocolException (org.apache.hc.core5.http.ProtocolException)2 ExecutableCommand (org.apache.hc.core5.http.nio.command.ExecutableCommand)2 HttpContext (org.apache.hc.core5.http.protocol.HttpContext)2 RawFrame (org.apache.hc.core5.http2.frame.RawFrame)2 AsyncPingHandler (org.apache.hc.core5.http2.nio.AsyncPingHandler)2 PingCommand (org.apache.hc.core5.http2.nio.command.PingCommand)2 CloseMode (org.apache.hc.core5.io.CloseMode)2 DockerClient (com.github.dockerjava.api.DockerClient)1