Examples of analyze()


Examples of com.asakusafw.modelgen.view.ViewAnalyzer.analyze()

            LOG.info("ビュー\"{}\"を解析しています", definition.name);
            CreateView tree = ViewParser.parse(definition);
            analyzer.add(Collections.singletonList(Constants.SOURCE_VIEW), tree);
        }

        List<ModelDescription> results = analyzer.analyze(repository);
        return results;
    }

    /**
     * データベースからビューの定義情報を収集し、ビュー名とSELECT文に対応する文字列のペアを返す。
 
View Full Code Here

Examples of com.caucho.bytecode.CodeEnhancer.analyze()

    baseClass.getMethodList().add(extMethod);

    try {
      InitAnalyzer initAnalyzer = new InitAnalyzer();
      CodeEnhancer baseEnhancer = new CodeEnhancer(baseClass, baseMethod.getCode());
      baseEnhancer.analyze(initAnalyzer);

      int offset = initAnalyzer.getOffset();
      byte []code = new byte[offset];
      byte []oldCode = baseEnhancer.getCode();
      System.arraycopy(oldCode, 0, code, 0, offset);
View Full Code Here

Examples of com.caucho.bytecode.CodeVisitor.analyze()

        else if (javaMethod.getName().startsWith("__caucho_super_"))
          continue;

        CodeVisitor visitor = new CodeVisitor(baseClass, javaMethod.getCode());

        visitor.analyze(analyzer, true);
      }
    }
  }

  /**
 
View Full Code Here

Examples of com.dianping.cat.analysis.MessageAnalyzer.analyze()

      queue.offer(newMessageTree(i, now + i * 10L));
    }

    MessageAnalyzer analyzer = manager.getAnalyzer("dump", now);

    analyzer.analyze(queue);
    analyzer.doCheckpoint(true);

    UploaderAndCleaner uploader = lookup(UploaderAndCleaner.class);

    uploader.setSleepPeriod(0);
View Full Code Here

Examples of com.esri.gpt.catalog.schema.indexable.tp.TpAnalyzer.analyze()

      }
    }

    // analyze the time period of the content
    TpAnalyzer tp = new TpAnalyzer();
    tp.analyze(this,schema,dom,sTitle);
   
  }
 
  /**
   * Resolves any inconsistencies associated with the resource URL.
View Full Code Here

Examples of com.facebook.presto.sql.analyzer.Analyzer.analyze()

        PlanOptimizersFactory planOptimizersFactory = new PlanOptimizersFactory(metadata);

        QueryExplainer queryExplainer = new QueryExplainer(session, planOptimizersFactory.get(), metadata, new MockPeriodicImportManager(), new MockStorageManager());
        Analyzer analyzer = new Analyzer(session, metadata, Optional.of(queryExplainer));

        Analysis analysis = analyzer.analyze(statement);

        Plan plan = new LogicalPlanner(session, planOptimizersFactory.get(), idAllocator, metadata, new MockPeriodicImportManager(), new MockStorageManager()).plan(analysis);
        if (printPlan) {
            System.out.println(PlanPrinter.textLogicalPlan(plan.getRoot(), plan.getTypes()));
        }
View Full Code Here

Examples of com.facebook.presto.sql.analyzer.ExpressionAnalyzer.analyze()

                        {
                            return Field.newUnqualified(symbol.getName(), symbolAllocator.getTypes().get(symbol));
                        }
                    })
                    .list();
            return expressionAnalyzer.analyze(expression, new TupleDescriptor(fields), new AnalysisContext());
        }

        private JoinNode tryNormalizeToInnerJoin(JoinNode node, Expression inheritedPredicate)
        {
            Preconditions.checkArgument(EnumSet.of(INNER, RIGHT, LEFT, CROSS).contains(node.getType()), "Unsupported join type: %s", node.getType());
View Full Code Here

Examples of com.google.code.apis.rest.client.Wadl.Analyzer.analyze()

    for(int i = 0; i < separatedRequestStrings.length; i++) {          
      RequestUriTree requestUriTree = new RequestUriTree(separatedRequestStrings[i]);
      RequestUriPanel.uriTree.addItem(requestUriTree);    
     
      Analyzer analyzer = new Analyzer(separatedRequestStrings[i]);     
      application = analyzer.analyze();
    }   
    WadlTreeRoot wadlTreeRoot = new WadlTreeRoot();
    Tree wadlTree = wadlTreeRoot.buildTree(application);
   
    WadlPanel.wadlArea.setWidget(wadlTree);
View Full Code Here

Examples of com.googlecode.aviator.asm.tree.analysis.Analyzer.analyze()

            MethodNode method = (MethodNode) methods.get(i);
            Analyzer a = new Analyzer(new SimpleVerifier(Type.getObjectType(cn.name),
                    Type.getObjectType(cn.superName),
                    false));
            try {
                a.analyze(cn.name, method);
                if (!dump) {
                    continue;
                }
            } catch (Exception e) {
                e.printStackTrace();
View Full Code Here

Examples of com.jgaap.classifiers.NearestNeighborDriver.analyze()

    Document unknownDocument = new Document();
    unknownDocument.addEventSet(null, unknown);

    System.out.println("There once was a lass from Nantucket");
    nearest.train(knowns);
    List<Pair<String, Double>> t = nearest.analyze(unknownDocument);
    String r = t.get(0).getFirst();

    String s = "Mary";

    assertTrue(r.startsWith(s));
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.