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.client;
019
020import org.apache.hadoop.conf.Configuration;
021import org.apache.hadoop.hbase.HConstants;
022import org.apache.yetus.audience.InterfaceAudience;
023
024/**
025 * Configuration parameters for the connection. Configuration is a heavy weight registry that does a
026 * lot of string operations and regex matching. Method calls into Configuration account for high CPU
027 * usage and have huge performance impact. This class caches connection-related configuration values
028 * in the ConnectionConfiguration object so that expensive conf.getXXX() calls are avoided every
029 * time HTable, etc is instantiated. see HBASE-12128
030 */
031@InterfaceAudience.Private
032public class ConnectionConfiguration {
033
034  public static final String WRITE_BUFFER_SIZE_KEY = "hbase.client.write.buffer";
035  public static final long WRITE_BUFFER_SIZE_DEFAULT = 2097152;
036  public static final String WRITE_BUFFER_PERIODIC_FLUSH_TIMEOUT_MS =
037    "hbase.client.write.buffer.periodicflush.timeout.ms";
038  public static final String WRITE_BUFFER_PERIODIC_FLUSH_TIMERTICK_MS =
039    "hbase.client.write.buffer.periodicflush.timertick.ms";
040  public static final long WRITE_BUFFER_PERIODIC_FLUSH_TIMEOUT_MS_DEFAULT = 0; // 0 == Disabled
041  public static final long WRITE_BUFFER_PERIODIC_FLUSH_TIMERTICK_MS_DEFAULT = 1000L; // 1 second
042  public static final String MAX_KEYVALUE_SIZE_KEY = "hbase.client.keyvalue.maxsize";
043  public static final int MAX_KEYVALUE_SIZE_DEFAULT = 10485760;
044  public static final String BUFFERED_MUTATOR_MAX_MUTATIONS_KEY =
045    "hbase.client.write.buffer.maxmutations";
046  public static final int BUFFERED_MUTATOR_MAX_MUTATIONS_DEFAULT = -1;
047  public static final String PRIMARY_CALL_TIMEOUT_MICROSECOND =
048    "hbase.client.primaryCallTimeout.get";
049  public static final int PRIMARY_CALL_TIMEOUT_MICROSECOND_DEFAULT = 10000; // 10ms
050  public static final String PRIMARY_SCAN_TIMEOUT_MICROSECOND =
051    "hbase.client.replicaCallTimeout.scan";
052  public static final int PRIMARY_SCAN_TIMEOUT_MICROSECOND_DEFAULT = 1000000; // 1s
053  public static final String LOG_SCANNER_ACTIVITY = "hbase.client.log.scanner.activity";
054
055  public static final String HBASE_CLIENT_META_READ_RPC_TIMEOUT_KEY =
056    "hbase.client.meta.read.rpc.timeout";
057  public static final String HBASE_CLIENT_META_SCANNER_TIMEOUT =
058    "hbase.client.meta.scanner.timeout.period";
059
060  private final long writeBufferSize;
061  private final long writeBufferPeriodicFlushTimeoutMs;
062  private final long writeBufferPeriodicFlushTimerTickMs;
063  private final int metaOperationTimeout;
064  private final int operationTimeout;
065  private final int scannerCaching;
066  private final long scannerMaxResultSize;
067  private final int primaryCallTimeoutMicroSecond;
068  private final int replicaCallTimeoutMicroSecondScan;
069  private final int metaReplicaCallTimeoutMicroSecondScan;
070  private final int retries;
071  private final int maxKeyValueSize;
072  private final int bufferedMutatorMaxMutations;
073  private final int rpcTimeout;
074  private final int readRpcTimeout;
075  private final int metaReadRpcTimeout;
076  private final int writeRpcTimeout;
077  // toggle for async/sync prefetch
078  private final boolean clientScannerAsyncPrefetch;
079
080  /**
081   * Constructor
082   * @param conf Configuration object
083   */
084  ConnectionConfiguration(Configuration conf) {
085    this.writeBufferSize = conf.getLong(WRITE_BUFFER_SIZE_KEY, WRITE_BUFFER_SIZE_DEFAULT);
086
087    this.writeBufferPeriodicFlushTimeoutMs = conf.getLong(WRITE_BUFFER_PERIODIC_FLUSH_TIMEOUT_MS,
088      WRITE_BUFFER_PERIODIC_FLUSH_TIMEOUT_MS_DEFAULT);
089
090    this.writeBufferPeriodicFlushTimerTickMs = conf.getLong(
091      WRITE_BUFFER_PERIODIC_FLUSH_TIMERTICK_MS, WRITE_BUFFER_PERIODIC_FLUSH_TIMERTICK_MS_DEFAULT);
092
093    this.metaOperationTimeout = conf.getInt(HConstants.HBASE_CLIENT_META_OPERATION_TIMEOUT,
094      conf.getInt(HConstants.HBASE_CLIENT_OPERATION_TIMEOUT,
095        HConstants.DEFAULT_HBASE_CLIENT_OPERATION_TIMEOUT));
096
097    this.operationTimeout = conf.getInt(HConstants.HBASE_CLIENT_OPERATION_TIMEOUT,
098      HConstants.DEFAULT_HBASE_CLIENT_OPERATION_TIMEOUT);
099
100    this.scannerCaching = conf.getInt(HConstants.HBASE_CLIENT_SCANNER_CACHING,
101      HConstants.DEFAULT_HBASE_CLIENT_SCANNER_CACHING);
102
103    this.scannerMaxResultSize = conf.getLong(HConstants.HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE_KEY,
104      HConstants.DEFAULT_HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE);
105
106    this.primaryCallTimeoutMicroSecond =
107      conf.getInt(PRIMARY_CALL_TIMEOUT_MICROSECOND, PRIMARY_CALL_TIMEOUT_MICROSECOND_DEFAULT);
108
109    this.replicaCallTimeoutMicroSecondScan =
110      conf.getInt(PRIMARY_SCAN_TIMEOUT_MICROSECOND, PRIMARY_SCAN_TIMEOUT_MICROSECOND_DEFAULT);
111
112    this.metaReplicaCallTimeoutMicroSecondScan =
113      conf.getInt(HConstants.HBASE_CLIENT_META_REPLICA_SCAN_TIMEOUT,
114        HConstants.HBASE_CLIENT_META_REPLICA_SCAN_TIMEOUT_DEFAULT);
115
116    this.retries = conf.getInt(HConstants.HBASE_CLIENT_RETRIES_NUMBER,
117      HConstants.DEFAULT_HBASE_CLIENT_RETRIES_NUMBER);
118
119    this.clientScannerAsyncPrefetch = conf.getBoolean(Scan.HBASE_CLIENT_SCANNER_ASYNC_PREFETCH,
120      Scan.DEFAULT_HBASE_CLIENT_SCANNER_ASYNC_PREFETCH);
121
122    this.maxKeyValueSize = conf.getInt(MAX_KEYVALUE_SIZE_KEY, MAX_KEYVALUE_SIZE_DEFAULT);
123
124    this.bufferedMutatorMaxMutations =
125      conf.getInt(BUFFERED_MUTATOR_MAX_MUTATIONS_KEY, BUFFERED_MUTATOR_MAX_MUTATIONS_DEFAULT);
126
127    this.rpcTimeout =
128      conf.getInt(HConstants.HBASE_RPC_TIMEOUT_KEY, HConstants.DEFAULT_HBASE_RPC_TIMEOUT);
129
130    this.readRpcTimeout = conf.getInt(HConstants.HBASE_RPC_READ_TIMEOUT_KEY,
131      conf.getInt(HConstants.HBASE_RPC_TIMEOUT_KEY, HConstants.DEFAULT_HBASE_RPC_TIMEOUT));
132
133    this.metaReadRpcTimeout = conf.getInt(HBASE_CLIENT_META_READ_RPC_TIMEOUT_KEY, readRpcTimeout);
134
135    this.writeRpcTimeout = conf.getInt(HConstants.HBASE_RPC_WRITE_TIMEOUT_KEY,
136      conf.getInt(HConstants.HBASE_RPC_TIMEOUT_KEY, HConstants.DEFAULT_HBASE_RPC_TIMEOUT));
137  }
138
139  /**
140   * Constructor This is for internal testing purpose (using the default value). In real usage, we
141   * should read the configuration from the Configuration object.
142   */
143  protected ConnectionConfiguration() {
144    this.writeBufferSize = WRITE_BUFFER_SIZE_DEFAULT;
145    this.writeBufferPeriodicFlushTimeoutMs = WRITE_BUFFER_PERIODIC_FLUSH_TIMEOUT_MS_DEFAULT;
146    this.writeBufferPeriodicFlushTimerTickMs = WRITE_BUFFER_PERIODIC_FLUSH_TIMERTICK_MS_DEFAULT;
147    this.metaOperationTimeout = HConstants.DEFAULT_HBASE_CLIENT_OPERATION_TIMEOUT;
148    this.operationTimeout = HConstants.DEFAULT_HBASE_CLIENT_OPERATION_TIMEOUT;
149    this.scannerCaching = HConstants.DEFAULT_HBASE_CLIENT_SCANNER_CACHING;
150    this.scannerMaxResultSize = HConstants.DEFAULT_HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE;
151    this.primaryCallTimeoutMicroSecond = 10000;
152    this.replicaCallTimeoutMicroSecondScan = 1000000;
153    this.metaReplicaCallTimeoutMicroSecondScan =
154      HConstants.HBASE_CLIENT_META_REPLICA_SCAN_TIMEOUT_DEFAULT;
155    this.retries = HConstants.DEFAULT_HBASE_CLIENT_RETRIES_NUMBER;
156    this.clientScannerAsyncPrefetch = Scan.DEFAULT_HBASE_CLIENT_SCANNER_ASYNC_PREFETCH;
157    this.maxKeyValueSize = MAX_KEYVALUE_SIZE_DEFAULT;
158    this.bufferedMutatorMaxMutations = BUFFERED_MUTATOR_MAX_MUTATIONS_DEFAULT;
159    this.readRpcTimeout = HConstants.DEFAULT_HBASE_RPC_TIMEOUT;
160    this.metaReadRpcTimeout = HConstants.DEFAULT_HBASE_RPC_TIMEOUT;
161    this.writeRpcTimeout = HConstants.DEFAULT_HBASE_RPC_TIMEOUT;
162    this.rpcTimeout = HConstants.DEFAULT_HBASE_RPC_TIMEOUT;
163  }
164
165  public int getReadRpcTimeout() {
166    return readRpcTimeout;
167  }
168
169  public int getMetaReadRpcTimeout() {
170    return metaReadRpcTimeout;
171  }
172
173  public int getWriteRpcTimeout() {
174    return writeRpcTimeout;
175  }
176
177  public long getWriteBufferSize() {
178    return writeBufferSize;
179  }
180
181  public long getWriteBufferPeriodicFlushTimeoutMs() {
182    return writeBufferPeriodicFlushTimeoutMs;
183  }
184
185  public long getWriteBufferPeriodicFlushTimerTickMs() {
186    return writeBufferPeriodicFlushTimerTickMs;
187  }
188
189  public int getMetaOperationTimeout() {
190    return metaOperationTimeout;
191  }
192
193  public int getOperationTimeout() {
194    return operationTimeout;
195  }
196
197  public int getScannerCaching() {
198    return scannerCaching;
199  }
200
201  public int getPrimaryCallTimeoutMicroSecond() {
202    return primaryCallTimeoutMicroSecond;
203  }
204
205  public int getReplicaCallTimeoutMicroSecondScan() {
206    return replicaCallTimeoutMicroSecondScan;
207  }
208
209  public int getMetaReplicaCallTimeoutMicroSecondScan() {
210    return metaReplicaCallTimeoutMicroSecondScan;
211  }
212
213  public int getRetriesNumber() {
214    return retries;
215  }
216
217  public int getMaxKeyValueSize() {
218    return maxKeyValueSize;
219  }
220
221  public int getBufferedMutatorMaxMutations() {
222    return bufferedMutatorMaxMutations;
223  }
224
225  public long getScannerMaxResultSize() {
226    return scannerMaxResultSize;
227  }
228
229  public boolean isClientScannerAsyncPrefetch() {
230    return clientScannerAsyncPrefetch;
231  }
232
233  public int getRpcTimeout() {
234    return rpcTimeout;
235  }
236}