Package org.apache.hadoop.hbase.util.RetryCounter

Examples of org.apache.hadoop.hbase.util.RetryCounter.RetryConfig


@InterfaceAudience.Private
public class RetryCounterFactory {
  private final RetryConfig retryConfig;

  public RetryCounterFactory(int maxAttempts, int sleepIntervalMillis) {
    this(new RetryConfig(
      maxAttempts,
      sleepIntervalMillis,
      -1,
      TimeUnit.MILLISECONDS,
      new ExponentialBackoffPolicy()));
View Full Code Here


    if ((sshUserName != null && sshUserName.length() > 0) ||
        (sshOptions != null && sshOptions.length() > 0)) {
      LOG.info("Running with SSH user [" + sshUserName + "] and options [" + sshOptions + "]");
    }

    this.retryCounterFactory = new RetryCounterFactory(new RetryConfig()
        .setMaxAttempts(conf.getInt(RETRY_ATTEMPTS_KEY, DEFAULT_RETRY_ATTEMPTS))
        .setSleepInterval(conf.getLong(RETRY_SLEEP_INTERVAL_KEY, DEFAULT_RETRY_SLEEP_INTERVAL)));
  }
View Full Code Here

@InterfaceAudience.Private
public class RetryCounterFactory {
  private final RetryConfig retryConfig;

  public RetryCounterFactory(int maxAttempts, int sleepIntervalMillis) {
    this(new RetryConfig(
      maxAttempts,
      sleepIntervalMillis,
      -1,
      TimeUnit.MILLISECONDS,
      new ExponentialBackoffPolicy()));
View Full Code Here

    if ((sshUserName != null && sshUserName.length() > 0) ||
        (sshOptions != null && sshOptions.length() > 0)) {
      LOG.info("Running with SSH user [" + sshUserName + "] and options [" + sshOptions + "]");
    }

    this.retryCounterFactory = new RetryCounterFactory(new RetryConfig()
        .setMaxAttempts(conf.getInt(RETRY_ATTEMPTS_KEY, DEFAULT_RETRY_ATTEMPTS))
        .setSleepInterval(conf.getLong(RETRY_SLEEP_INTERVAL_KEY, DEFAULT_RETRY_SLEEP_INTERVAL)));
  }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hbase.util.RetryCounter.RetryConfig

Copyright © 2018 www.massapicom. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.