Package org.apache.hadoop.hbase.client.tableindexed

Examples of org.apache.hadoop.hbase.client.tableindexed.IndexedTableDescriptor


  public IndexedRegion(final Path basedir, final HLog log, final FileSystem fs,
      final HBaseConfiguration conf, final HRegionInfo regionInfo,
      final FlushRequester flushListener, Leases trxLeases) throws IOException {
    super(basedir, log, fs, conf, regionInfo, flushListener, trxLeases);
    this.indexTableDescriptor = new IndexedTableDescriptor(regionInfo.getTableDesc());
    this.conf = conf;
  }
View Full Code Here


  public IndexedRegion(final Path basedir, final HLog log, final FileSystem fs,
      final HBaseConfiguration conf, final HRegionInfo regionInfo,
      final FlushRequester flushListener, Leases trxLeases) throws IOException {
    super(basedir, log, fs, conf, regionInfo, flushListener, trxLeases);
    this.indexTableDescriptor = new IndexedTableDescriptor(regionInfo.getTableDesc());
    this.conf = conf;
  }
View Full Code Here

  public IndexedRegion(final Path basedir, final HLog log, final FileSystem fs,
      final HBaseConfiguration conf, final HRegionInfo regionInfo,
      final FlushRequester flushListener, Leases trxLeases) throws IOException {
    super(basedir, log, fs, conf, regionInfo, flushListener, trxLeases);
    this.indexTableDescriptor = new IndexedTableDescriptor(regionInfo.getTableDesc());
    this.conf = conf;
  }
View Full Code Here

                               + "\n    Bloomfilter type: " + columnDesc.getBloomFilterType().name()
                               + "\n    In memory: " + columnDesc.isInMemory()
                               + "\n");
        }

        final IndexedTableDescriptor indexDesc = conn.newIndexedTableDescriptor(this.getTableName());
        final Collection<IndexSpecification> indexes = indexDesc.getIndexes();
        if (indexes.isEmpty()) {
            retval.out.println("No table indexes.");
        }
        else {
            retval.out.println("Table indexes:");
View Full Code Here

    public IndexedTableDescriptor newIndexedTableDescriptor(final String tableName) throws HBqlException {
        this.checkIfClosed();
        try {
            final HTableDescriptor tableDesc = this.getHTableDescriptor(tableName);
            return new IndexedTableDescriptor(tableDesc);
        }
        catch (IOException e) {
            throw new HBqlException(e);
        }
    }
View Full Code Here

        final TableMapping mapping = this.getMapping(mappingName);
        return this.indexExistsForTable(indexName, mapping.getTableName());
    }

    public IndexSpecification getIndexForTable(final String indexName, final String tableName) throws HBqlException {
        final IndexedTableDescriptor indexDesc = this.newIndexedTableDescriptor(tableName);
        return indexDesc.getIndex(indexName);
    }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hbase.client.tableindexed.IndexedTableDescriptor

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.