Package org.apache.hadoop.hbase.master

Examples of org.apache.hadoop.hbase.master.RackManager


  private List<ServerName> servers;
  public static final byte [] FAVOREDNODES_QUALIFIER = Bytes.toBytes("fn");
  public final static short FAVORED_NODES_NUM = 3;

  public FavoredNodeAssignmentHelper(final List<ServerName> servers, Configuration conf) {
    this(servers, new RackManager(conf));
  }
View Full Code Here


  Configuration conf;

  @Override
  public void setConf(Configuration conf) {
    globalFavoredNodesAssignmentPlan = new FavoredNodesPlan();
    this.rackManager = new RackManager(conf);
    this.conf = conf;
  }
View Full Code Here

  private List<ServerName> servers;
  public static final byte [] FAVOREDNODES_QUALIFIER = Bytes.toBytes("fn");
  public final static short FAVORED_NODES_NUM = 3;

  public FavoredNodeAssignmentHelper(final List<ServerName> servers, Configuration conf) {
    this(servers, new RackManager(conf));
  }
View Full Code Here

  private List<ServerName> servers;
  public static final byte [] FAVOREDNODES_QUALIFIER = Bytes.toBytes("fn");
  public final static short FAVORED_NODES_NUM = 3;

  public FavoredNodeAssignmentHelper(final List<ServerName> servers, Configuration conf) {
    this(servers, new RackManager(conf));
  }
View Full Code Here

  private RackManager rackManager;

  @Override
  public void setConf(Configuration conf) {
    globalFavoredNodesAssignmentPlan = new FavoredNodes();
    this.rackManager = new RackManager(conf);
  }
View Full Code Here

  @Override
  public void setConf(Configuration conf) {
    super.setConf(conf);
    globalFavoredNodesAssignmentPlan = new FavoredNodesPlan();
    this.rackManager = new RackManager(conf);
    super.setConf(conf);
  }
View Full Code Here

    if (tables != null) {
      for (String table: tables) {
        tablesOnMaster.add(table);
      }
    }
    this.rackManager = new RackManager(getConf());
    regionFinder.setConf(conf);
  }
View Full Code Here

  private List<ServerName> servers;
  public static final byte [] FAVOREDNODES_QUALIFIER = Bytes.toBytes("fn");
  public final static short FAVORED_NODES_NUM = 3;

  public FavoredNodeAssignmentHelper(final List<ServerName> servers, Configuration conf) {
    this(servers, new RackManager(conf));
  }
View Full Code Here

    int numRegionsPerServer = 28;
    int numTables = 10;
    int numRacks = 4; // all replicas should be on a different rack
    Map<ServerName, List<HRegionInfo>> serverMap =
        createServerMap(numNodes, numRegions, numRegionsPerServer, replication, numTables);
    RackManager rm = new ForTestRackManager(numRacks);

    testWithCluster(serverMap, rm, false, true);
  }
View Full Code Here

    this.config = conf;
    String[] tables = getTablesOnMaster(conf);
    if (tables != null && tables.length > 0) {
      Collections.addAll(tablesOnMaster, tables);
    }
    this.rackManager = new RackManager(getConf());
    regionFinder.setConf(conf);
  }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hbase.master.RackManager

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.