001/*
002 * Licensed to the Apache Software Foundation (ASF) under one
003 * or more contributor license agreements.  See the NOTICE file
004 * distributed with this work for additional information
005 * regarding copyright ownership.  The ASF licenses this file
006 * to you under the Apache License, Version 2.0 (the
007 * "License"); you may not use this file except in compliance
008 * with the License.  You may obtain a copy of the License at
009 *
010 *     http://www.apache.org/licenses/LICENSE-2.0
011 *
012 * Unless required by applicable law or agreed to in writing, software
013 * distributed under the License is distributed on an "AS IS" BASIS,
014 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
015 * See the License for the specific language governing permissions and
016 * limitations under the License.
017 */
018package org.apache.hadoop.hbase.ipc;
019
020import java.io.IOException;
021import java.net.InetAddress;
022import org.apache.hadoop.hbase.CellScanner;
023import org.apache.hadoop.hbase.io.ByteBuffAllocator;
024import org.apache.hadoop.hbase.ipc.RpcServer.CallCleanup;
025import org.apache.yetus.audience.InterfaceAudience;
026
027import org.apache.hbase.thirdparty.com.google.protobuf.BlockingService;
028import org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor;
029import org.apache.hbase.thirdparty.com.google.protobuf.Message;
030
031import org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader;
032
033/**
034 * Datastructure that holds all necessary to a method invocation and then afterward, carries the
035 * result.
036 */
037@Deprecated
038@InterfaceAudience.Private
039class SimpleServerCall extends ServerCall<SimpleServerRpcConnection> {
040
041  final SimpleRpcServerResponder responder;
042
043  @edu.umd.cs.findbugs.annotations.SuppressWarnings(value = "NP_NULL_ON_SOME_PATH",
044      justification = "Can't figure why this complaint is happening... see below")
045  SimpleServerCall(int id, final BlockingService service, final MethodDescriptor md,
046    RequestHeader header, Message param, CellScanner cellScanner,
047    SimpleServerRpcConnection connection, long size, final InetAddress remoteAddress,
048    long receiveTime, int timeout, ByteBuffAllocator bbAllocator, CellBlockBuilder cellBlockBuilder,
049    CallCleanup reqCleanup, SimpleRpcServerResponder responder) {
050    super(id, service, md, header, param, cellScanner, connection, size, remoteAddress, receiveTime,
051      timeout, bbAllocator, cellBlockBuilder, reqCleanup);
052    this.responder = responder;
053  }
054
055  /**
056   * Call is done. Execution happened and we returned results to client. It is now safe to cleanup.
057   */
058  @edu.umd.cs.findbugs.annotations.SuppressWarnings(value = "IS2_INCONSISTENT_SYNC",
059      justification = "Presume the lock on processing request held by caller is protection enough")
060  @Override
061  public void done() {
062    super.done();
063    this.getConnection().decRpcCount(); // Say that we're done with this call.
064  }
065
066  @Override
067  public synchronized void sendResponseIfReady() throws IOException {
068    // set param null to reduce memory pressure
069    this.param = null;
070    this.responder.doRespond(getConnection(), this);
071  }
072
073  SimpleServerRpcConnection getConnection() {
074    return this.connection;
075  }
076}