Examples of Scanner


Examples of com.nearinfinity.honeycomb.Scanner

        Table t = store.openTable(tableName);
        TableSchema schema = store.getSchema(tableName);
        IndexSchema indexSchema = schema.getIndexSchema(indexName);

        QueryKey key = new QueryKey(indexName, QueryType.EXACT_KEY, row.getRecords());
        Scanner scanner = t.indexScanExact(key);

        try {
            while (scanner.hasNext()) {
                Row next = Row.deserialize(scanner.next());
                if (!next.getUUID().equals(row.getUUID())) {
                    // Special case for inserting nulls
                    for (String column : indexSchema.getColumns()) {
                        boolean isNullInRecord = !row.getRecords().containsKey(column);
                        if (isNullInRecord) {
View Full Code Here

Examples of com.salesforce.hbase.index.scanner.Scanner

   */
  private IndexUpdate getIndexUpdateForGroup(ColumnGroup group, TableState state) {
    List<CoveredColumn> refs = group.getColumns();
    try {
      Pair<Scanner, IndexUpdate> stateInfo = state.getIndexedColumnsTableState(refs);
      Scanner kvs = stateInfo.getFirst();
      Pair<Integer, List<ColumnEntry>> columns =
          getNextEntries(refs, kvs, state.getCurrentRowKey());
      // make sure we close the scanner
      kvs.close();
      if (columns.getFirst().intValue() == 0) {
        return stateInfo.getSecond();
      }
      // have all the column entries, so just turn it into a Delete for the row
      // convert the entries to the needed values
View Full Code Here

Examples of com.sleepycat.je.recovery.RollbackTracker.Scanner

         *
         * We let the tracker know if it is the first pass or not, in order
         * to support some internal tracker assertions.
         */
        rollbackTracker.setFirstPass(firstUndoPass);
        final Scanner rollbackScanner =  rollbackTracker.getScanner();

        try {

            /*
             * Iterate over the target LNs and commit records, constructing the
             * tree.
             */
            while (reader.readNextEntry()) {
                counter.incNumRead();
                if (reader.isLN()) {

                    /* Get the txnId from the log entry. */
                    Long txnId = reader.getTxnId();

                    /* Skip past this, no need to undo non-txnal LNs. */
                    if (txnId == null) {
                        continue;
                    }

                    if (rollbackScanner.positionAndCheck(reader.getLastLsn(),
                                                         txnId)) {
                        /*
                         * If an LN is in the rollback period and was part of a
                         * rollback, let the rollback scanner decide how it
                         * should be handled. This does not include LNs that
                         * were explicitly aborted.
                         */
                        rollbackScanner.rollback(txnId, reader, tracker);
                        continue;
                    }

                    /* This LN is part of a committed txn. */
                    if (committedTxnIds.containsKey(txnId)) {
View Full Code Here

Examples of com.softwarementors.extjs.djn.scanner.Scanner

    subtaskTimer.stop();
    subtaskTimer.logDebugTimeInMilliseconds("Djn initialization: Servlet Configuration Load time");
   
    subtaskTimer.restart();
    Registry registry = new Registry( globalConfiguration );
    Scanner scanner = new Scanner(registry);
    scanner.scanAndRegisterApiConfigurations( apiConfigurations );
    subtaskTimer.stop();
    subtaskTimer.logDebugTimeInMilliseconds("Djn initialization: Standard Api processing time");

    if( registryConfiguratorClass != null ) {
      subtaskTimer.restart();
View Full Code Here

Examples of com.sun.enterprise.deployment.annotation.Scanner

    }

    public static Scanner createScanner(BundleDescriptor bundleDesc,
            Archivist archivist, AbstractArchive abstractArchive,
            ClassLoader classLoader) throws IOException {
        Scanner scanner = null;
        File f = new File(abstractArchive.getArchiveUri());

        if (ModuleType.EJB.equals(archivist.getModuleType())) {
            scanner = new EjbJarScanner(f, (EjbBundleDescriptor)bundleDesc,
                   classLoader);
View Full Code Here

Examples of com.sun.jersey.core.spi.scanning.Scanner

          return new AnnotationDictionary(input);
        }
      });

  public void scan(URLClassLoader classLoader) {
    Scanner scanner = buildScanner(classLoader);

    AnnotationScannerListener listener = new AnnotationScannerListener(ANNOTATIONS);
    scanner.scan(listener);

    for (Class<?> clazz : listener.getAnnotatedClasses()) {
      for (Class<? extends Annotation> annotation : ANNOTATIONS) {
        if (clazz.isAnnotationPresent(annotation)) {
          AnnotationDictionary annotationDictionary = getAnnotationDictionary(annotation);
View Full Code Here

Examples of com.sun.tools.javac.parser.Scanner

        JavaFileObject prev = compiler.log.useSource(null);
        Scanner.Factory scannerFactory = Scanner.Factory.instance(context);
        Parser.Factory parserFactory = Parser.Factory.instance(context);
        Attr attr = Attr.instance(context);
        try {
            Scanner scanner = scannerFactory.newScanner((expr+"\u0000").toCharArray(),
                                                        expr.length());
            Parser parser = parserFactory.newParser(scanner, false, false);
            JCTree tree = parser.type();
            return attr.attribType(tree, (Symbol.TypeSymbol)scope);
        } finally {
View Full Code Here

Examples of de.odysseus.el.tree.impl.Scanner

    /**
     * Use a modified scanner which recognizes <code>'~'</code> and keyword <code>'matches'</code>.
     */
    @Override
    protected Scanner createScanner(String expression) {
      return new Scanner(expression) {
        @Override
        protected Token keyword(String s) {
          if ("matches".equals(s)) {
            return KEYWORD;
          }
View Full Code Here

Examples of dovetaildb.scan.Scanner

          }
          if (cmp2 >= 0) {
            if (cmp2 < 0) break;
            if (term2IsExclusive) break;
          }
          Scanner scanner = null;
          if (isRanged) {
            byte[] minTerm = (cmp1 > 0) ? termValue1 : null;
            byte[] maxTerm = (cmp3 < 0) ? termValue2 : null;
            scanner = new RangeScanner(pvf, page, vfPair,
                minTerm, term1IsExclusive,
View Full Code Here

Examples of java.util.Scanner

   
    /**
     * Load the resources from file.
     */
    private void load() {
        Scanner scanner = null;
        try {
           
            scanner = new Scanner(file, "UTF-8");
            while (scanner.hasNextLine()) {
                String line = scanner.nextLine();

                String[] values = line.split("=");
                if (values != null && values.length >= 2) {
                    String value = values[1];
                    if (values.length > 2) {
View Full Code Here
TOP
Copyright © 2018 www.massapi.com. 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.