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 org.apache.hbase.thirdparty.com.google.protobuf.BlockingRpcChannel;
021import org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel;
022
023import java.io.Closeable;
024import java.io.IOException;
025
026import org.apache.hadoop.hbase.ServerName;
027import org.apache.yetus.audience.InterfaceAudience;
028import org.apache.hadoop.hbase.security.User;
029
030/**
031 * Interface for RpcClient implementations so ConnectionManager can handle it.
032 */
033@InterfaceAudience.Private
034public interface RpcClient extends Closeable {
035  String FAILED_SERVER_EXPIRY_KEY = "hbase.ipc.client.failed.servers.expiry";
036  int FAILED_SERVER_EXPIRY_DEFAULT = 2000;
037  String IDLE_TIME = "hbase.ipc.client.connection.minIdleTimeBeforeClose";
038  String IPC_CLIENT_FALLBACK_TO_SIMPLE_AUTH_ALLOWED_KEY =
039      "hbase.ipc.client.fallback-to-simple-auth-allowed";
040  boolean IPC_CLIENT_FALLBACK_TO_SIMPLE_AUTH_ALLOWED_DEFAULT = false;
041  String SPECIFIC_WRITE_THREAD = "hbase.ipc.client.specificThreadForWriting";
042  String DEFAULT_CODEC_CLASS = "hbase.client.default.rpc.codec";
043
044  String SOCKET_TIMEOUT_CONNECT = "hbase.ipc.client.socket.timeout.connect";
045  /**
046   * How long we wait when we wait for an answer. It's not the operation time, it's the time
047   * we wait when we start to receive an answer, when the remote write starts to send the data.
048   */
049  String SOCKET_TIMEOUT_READ = "hbase.ipc.client.socket.timeout.read";
050  String SOCKET_TIMEOUT_WRITE = "hbase.ipc.client.socket.timeout.write";
051  int DEFAULT_SOCKET_TIMEOUT_CONNECT = 10000; // 10 seconds
052  int DEFAULT_SOCKET_TIMEOUT_READ = 20000; // 20 seconds
053  int DEFAULT_SOCKET_TIMEOUT_WRITE = 60000; // 60 seconds
054
055  // Used by the server, for compatibility with old clients.
056  // The client in 0.99+ does not ping the server.
057  int PING_CALL_ID = -1;
058
059  /**
060   * Creates a "channel" that can be used by a blocking protobuf service.  Useful setting up
061   * protobuf blocking stubs.
062   *
063   * @param sn server name describing location of server
064   * @param user which is to use the connection
065   * @param rpcTimeout default rpc operation timeout
066   *
067   * @return A blocking rpc channel that goes via this rpc client instance.
068   * @throws IOException when channel could not be created
069   */
070  BlockingRpcChannel createBlockingRpcChannel(ServerName sn, User user, int rpcTimeout)
071      throws IOException;
072
073  /**
074   * Creates a "channel" that can be used by a protobuf service.  Useful setting up
075   * protobuf stubs.
076   *
077   * @param sn server name describing location of server
078   * @param user which is to use the connection
079   * @param rpcTimeout default rpc operation timeout
080   *
081   * @return A rpc channel that goes via this rpc client instance.
082   */
083  RpcChannel createRpcChannel(final ServerName sn, final User user, int rpcTimeout)
084      throws IOException;
085
086  /**
087   * Interrupt the connections to the given server. This should be called if the server
088   * is known as actually dead. This will not prevent current operation to be retried, and,
089   * depending on their own behavior, they may retry on the same server. This can be a feature,
090   * for example at startup. In any case, they're likely to get connection refused (if the
091   * process died) or no route to host: i.e. their next retries should be faster and with a
092   * safe exception.
093   * @param sn server location to cancel connections of
094   */
095  void cancelConnections(ServerName sn);
096
097  /**
098   * Stop all threads related to this client.  No further calls may be made
099   * using this client.
100   */
101  @Override
102  void close();
103
104  /**
105   * @return true when this client uses a {@link org.apache.hadoop.hbase.codec.Codec} and so
106   *         supports cell blocks.
107   */
108  boolean hasCellBlockSupport();
109}