All Downloads are FREE. Search and download functionalities are using the official Maven repository.

org.glowroot.agent.shaded.grpc.internal.AbstractServerStream Maven / Gradle / Ivy

There is a newer version: 0.9.24
Show newest version
/*
 * Copyright 2014, Google Inc. All rights reserved.
 *
 * Redistribution and use in source and binary forms, with or without
 * modification, are permitted provided that the following conditions are
 * met:
 *
 *    * Redistributions of source code must retain the above copyright
 * notice, this list of conditions and the following disclaimer.
 *    * Redistributions in binary form must reproduce the above
 * copyright notice, this list of conditions and the following disclaimer
 * in the documentation and/or other materials provided with the
 * distribution.
 *
 *    * Neither the name of Google Inc. nor the names of its
 * contributors may be used to endorse or promote products derived from
 * this software without specific prior written permission.
 *
 * THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS
 * "AS IS" AND ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT
 * LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR
 * A PARTICULAR PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT
 * OWNER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL,
 * SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT
 * LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE,
 * DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY
 * THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT
 * (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
 * OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
 */

package org.glowroot.agent.shaded.grpc.internal;

import static org.glowroot.agent.shaded.google.common.base.Preconditions.checkNotNull;

import org.glowroot.agent.shaded.google.common.base.Preconditions;

import org.glowroot.agent.shaded.grpc.Metadata;
import org.glowroot.agent.shaded.grpc.Status;

import java.io.InputStream;
import org.glowroot.agent.jul.Level;
import org.glowroot.agent.jul.Logger;

/**
 * Abstract base class for {@link ServerStream} implementations.
 *
 * @param  the type of the stream identifier
 */
public abstract class AbstractServerStream extends AbstractStream
    implements ServerStream {
  private static final Logger log = Logger.getLogger(AbstractServerStream.class.getName());

  /** Whether listener.closed() has been called. */
  private boolean listenerClosed;
  private ServerStreamListener listener;

  private boolean headersSent = false;
  /**
   * Whether the stream was closed gracefully by the application (vs. a transport-level failure).
   */
  private boolean gracefulClose;
  /** Saved trailers from close() that need to be sent once the framer has sent all messages. */
  private Metadata stashedTrailers;

  protected AbstractServerStream(WritableBufferAllocator bufferAllocator,
                                 int maxMessageSize) {
    super(bufferAllocator, maxMessageSize);
  }

  /**
   * Sets the listener to receive notifications. Must be called in the context of the transport
   * thread.
   */
  public final void setListener(ServerStreamListener listener) {
    this.listener = checkNotNull(listener);

    // Now that the stream has actually been initialized, call the listener's onReady callback if
    // appropriate.
    onStreamAllocated();
  }

  @Override
  protected ServerStreamListener listener() {
    return listener;
  }

  @Override
  protected void receiveMessage(InputStream is) {
    inboundPhase(Phase.MESSAGE);
    listener().messageRead(is);
  }

  @Override
  public final void writeHeaders(Metadata headers) {
    Preconditions.checkNotNull(headers, "headers");

    outboundPhase(Phase.HEADERS);
    headersSent = true;
    internalSendHeaders(headers);
    outboundPhase(Phase.MESSAGE);
  }

  @Override
  public final void writeMessage(InputStream message) {
    if (outboundPhase() != Phase.MESSAGE) {
      throw new IllegalStateException("Messages are only permitted after headers and before close");
    }
    super.writeMessage(message);
  }

  @Override
  public final void close(Status status, Metadata trailers) {
    Preconditions.checkNotNull(status, "status");
    Preconditions.checkNotNull(trailers, "trailers");
    if (outboundPhase(Phase.STATUS) != Phase.STATUS) {
      gracefulClose = true;
      stashedTrailers = trailers;
      writeStatusToTrailers(status);
      closeFramer();
    }
  }

  private void writeStatusToTrailers(Status status) {
    stashedTrailers.removeAll(Status.CODE_KEY);
    stashedTrailers.removeAll(Status.MESSAGE_KEY);
    stashedTrailers.put(Status.CODE_KEY, status);
    if (status.getDescription() != null) {
      stashedTrailers.put(Status.MESSAGE_KEY, status.getDescription());
    }
  }

  /**
   * Called by transport implementations when they receive headers.
   *
   * @param headers the parsed headers
   */
  protected void inboundHeadersReceived(Metadata headers) {
    inboundPhase(Phase.MESSAGE);
  }

  /**
   * Called in the network thread to process the content of an inbound DATA frame from the client.
   *
   * @param frame the inbound HTTP/2 DATA frame. If this buffer is not used immediately, it must
   *              be retained.
   * @param endOfStream {@code true} if no more data will be received on the stream.
   */
  public void inboundDataReceived(ReadableBuffer frame, boolean endOfStream) {
    if (inboundPhase() == Phase.STATUS) {
      frame.close();
      return;
    }
    // Deframe the message. If a failure occurs, deframeFailed will be called.
    deframe(frame, endOfStream);
  }

  @Override
  protected final void deframeFailed(Throwable cause) {
    log.log(Level.WARNING, "Exception processing message", cause);
    abortStream(Status.fromThrowable(cause), true);
  }

  @Override
  protected final void internalSendFrame(WritableBuffer frame, boolean endOfStream, boolean flush) {
    if (frame != null) {
      sendFrame(frame, false, endOfStream ? false : flush);
    }
    if (endOfStream) {
      sendTrailers(stashedTrailers, headersSent);
      headersSent = true;
      stashedTrailers = null;
    }
  }

  /**
   * Sends response headers to the remote end points.
   *
   * @param headers the headers to be sent to client.
   */
  protected abstract void internalSendHeaders(Metadata headers);

  /**
   * Sends an outbound frame to the remote end point.
   *
   * @param frame a buffer containing the chunk of data to be sent.
   * @param endOfStream if {@code true} indicates that no more data will be sent on the stream by
   *        this endpoint.
   * @param flush {@code true} if more data may not be arriving soon
   */
  protected abstract void sendFrame(WritableBuffer frame, boolean endOfStream, boolean flush);

  /**
   * Sends trailers to the remote end point. This call implies end of stream.
   *
   * @param trailers metadata to be sent to end point
   * @param headersSent {@code true} if response headers have already been sent.
   */
  protected abstract void sendTrailers(Metadata trailers, boolean headersSent);

  /**
   * Indicates the stream is considered completely closed and there is no further opportunity for
   * error. It calls the listener's {@code closed()} if it was not already done by {@link
   * #abortStream}. Note that it is expected that either {@code closed()} or {@code abortStream()}
   * was previously called, since {@code closed()} is required for a normal stream closure and
   * {@code abortStream()} for abnormal.
   */
  public void complete() {
    if (!gracefulClose) {
      closeListener(Status.INTERNAL.withDescription("successful complete() without close()"));
      throw new IllegalStateException("successful complete() without close()");
    }
    closeListener(Status.OK);
  }

  /**
   * Called when the remote end half-closes the stream.
   */
  @Override
  protected final void remoteEndClosed() {
    halfCloseListener();
  }

  /**
   * Aborts the stream with an error status, cleans up resources and notifies the listener if
   * necessary.
   *
   * 

Unlike {@link #close(Status, Metadata)}, this method is only called from the * transport. The transport should use this method instead of {@code close(Status)} for internal * errors to prevent exposing unexpected states and exceptions to the application. * * @param status the error status. Must not be {@link Status#OK}. * @param notifyClient {@code true} if the stream is still writable and you want to notify the * client about stream closure and send the status */ public final void abortStream(Status status, boolean notifyClient) { // TODO(louiscryan): Investigate whether we can remove the notification to the client // and rely on a transport layer stream reset instead. Preconditions.checkArgument(!status.isOk(), "status must not be OK"); closeListener(status); if (notifyClient) { // TODO(louiscryan): Remove if (stashedTrailers == null) { stashedTrailers = new Metadata(); } writeStatusToTrailers(status); sendStreamAbortToClient(status, stashedTrailers); } } @Override public boolean isClosed() { return super.isClosed() || listenerClosed; } /** * Notifies the remote client that this stream has aborted. */ protected abstract void sendStreamAbortToClient(Status status, Metadata trailers); /** * Fires a half-closed event to the listener and frees inbound resources. */ private void halfCloseListener() { if (inboundPhase(Phase.STATUS) != Phase.STATUS && !listenerClosed) { closeDeframer(); listener().halfClosed(); } } /** * Closes the listener if not previously closed and frees resources. */ private void closeListener(Status newStatus) { if (!listenerClosed) { listenerClosed = true; closeDeframer(); listener().closed(newStatus); } } }





© 2015 - 2025 Weber Informatics LLC | Privacy Policy