Package org.apache.hadoop.hbase.thrift.generated

Examples of org.apache.hadoop.hbase.thrift.generated.IllegalArgument


      LOG.debug("scannerGetList: id=" + id);
      ResultScanner scanner = getScanner(id);
      if (null == scanner) {
        String message = "scanner ID is invalid";
        LOG.warn(message);
        throw new IllegalArgument("scanner ID is invalid");
      }

      Result [] results = null;
      try {
        results = scanner.next(nbRows);
View Full Code Here


      Compression.getCompressionAlgorithmByName(in.compression.toLowerCase());
    BloomType bt =
      BloomType.valueOf(in.bloomFilterType);

    if (in.name == null || !in.name.hasRemaining()) {
      throw new IllegalArgument("column name is empty");
    }
    byte [] parsedName = KeyValue.parseColumn(Bytes.getBytes(in.name))[0];
    HColumnDescriptor col = new HColumnDescriptor(parsedName)
        .setMaxVersions(in.maxVersions)
        .setCompressionType(comp)
View Full Code Here

        }
        admin.createTable(desc);
      } catch (IOException e) {
        throw new IOError(e.getMessage());
      } catch (IllegalArgumentException e) {
        throw new IllegalArgument(e.getMessage());
      }
    }
View Full Code Here

   
    public void scannerClose(int id) throws IOError, IllegalArgument {
      LOG.debug("scannerClose: id=" + id);
      HScannerInterface scanner = getScanner(id);
      if (scanner == null) {
        throw new IllegalArgument("scanner ID is invalid");
      }
      try {
        scanner.close();
        removeScanner(id);
      } catch (IOException e) {
View Full Code Here

    public ScanEntry scannerGet(int id) throws IllegalArgument, NotFound,
        IOError {
      LOG.debug("scannerGet: id=" + id);
      HScannerInterface scanner = getScanner(id);
      if (scanner == null) {
        throw new IllegalArgument("scanner ID is invalid");
      }
     
      HStoreKey key = new HStoreKey();
      TreeMap<Text, byte[]> results = new TreeMap<Text, byte[]>();
     
View Full Code Here

            in.bloomFilterNbHashes);
      } else if (in.bloomFilterVectorSize > 0) {
        bloom = new BloomFilterDescriptor(BloomFilterDescriptor.BloomFilterType
            .valueOf(in.bloomFilterType), in.bloomFilterVectorSize);
      } else {
        throw new IllegalArgument(
            "must specify number of entries for bloom filter");
      }
    }
   
    if (in.name == null || in.name.length <= 0) {
      throw new IllegalArgument("column name is empty");
    }
    HColumnDescriptor col = new HColumnDescriptor(new Text(in.name),
        in.maxVersions, comp, in.inMemory, in.maxValueLength, bloom);
    return col;
  }
View Full Code Here

        }
        admin.createTable(desc);
      } catch (IOException e) {
        throw new IOError(e.getMessage());
      } catch (IllegalArgumentException e) {
        throw new IllegalArgument(e.getMessage());
      }
    }
View Full Code Here

        }
        table.commit(batchUpdate);
      } catch (IOException e) {
        throw new IOError(e.getMessage());
      } catch (IllegalArgumentException e) {
        throw new IllegalArgument(e.getMessage());
      }
    }
View Full Code Here

        table = getTable(tableName);
        table.commit(batchUpdates);
      } catch (IOException e) {
        throw new IOError(e.getMessage());
      } catch (IllegalArgumentException e) {
        throw new IllegalArgument(e.getMessage());
      }
    }
View Full Code Here

    public void scannerClose(int id) throws IOError, IllegalArgument {
      LOG.debug("scannerClose: id=" + id);
      Scanner scanner = getScanner(id);
      if (scanner == null) {
        throw new IllegalArgument("scanner ID is invalid");
      }
      scanner.close();
      removeScanner(id);
    }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hbase.thrift.generated.IllegalArgument

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.