Examples of Node


Examples of com.eclipsesource.tabris.demos.enron.EnronDataset.Node

    @Override
    public void update( final ViewerCell cell ) {
      Object element = cell.getElement();
      if( element instanceof Node ) {
        Node node = ( Node )element;
        int columnIndex = cell.getColumnIndex();
        switch( columnIndex ) {
          case COLUMN_TITLE:
            updateTitle( cell, node );
          break;

Examples of com.enioka.jqm.jpamodel.Node

        // New EM (after setting thread name)
        EntityManager em = Helpers.getNewEm();

        // Get configuration data
        Node node = em.find(Node.class, this.engine.getNode().getId());
        this.step = Long.parseLong(Helpers.getParameter("internalPollingPeriodMs", String.valueOf(this.step), em));
        this.alive = Long.parseLong(Helpers.getParameter("aliveSignalMs", String.valueOf(this.step), em));
        em.close();
        this.localThread = Thread.currentThread();

        // Launch main loop
        long sinceLatestPing = 0;
        while (true)
        {
            try
            {
                Thread.sleep(this.step);
            }
            catch (InterruptedException e)
            {
                run = false;
            }
            if (!run)
            {
                break;
            }

            // Get session
            em = Helpers.getNewEm();

            // Check if stop order
            node = em.find(Node.class, node.getId());
            if (node.isStop())
            {
                jqmlogger.info("Node has received a stop order from the database");
                jqmlogger.trace("At stop order time, there are " + this.engine.getCurrentlyRunningJobCount() + " jobs running in the node");
                this.run = false;
                this.engine.stop();
                em.close();
                break;
            }

            // I am alive signal
            sinceLatestPing += this.step;
            if (sinceLatestPing >= this.alive * 0.9)
            {
                em.getTransaction().begin();
                em.createQuery("UPDATE Node n SET n.lastSeenAlive = current_timestamp() WHERE n.id = :id").setParameter("id", node.getId())
                        .executeUpdate();
                em.getTransaction().commit();
                sinceLatestPing = 0;
            }

Examples of com.espertech.esper.epl.join.rep.Node

        if (node == null)
        {
            return;
        }

        Node parent = node.getParent();
        if (parent == null)
        {
            lookupEventsPerStream[rootStreamNum] = node.getParentEvent();
            return;
        }

        lookupEventsPerStream[parent.getStream()] = node.getParentEvent();
        recursiveFill(lookupEventsPerStream, parent);
    }

Examples of com.facebook.presto.metadata.Node

            metadata.addInternalSchemaMetadata(new DualMetadata());

            StageExecutionPlan joinPlan = createJoinPlan("A", metadata);

            InMemoryNodeManager nodeManager = new InMemoryNodeManager();
            nodeManager.addNode("foo", new Node("other", URI.create("http://127.0.0.1:11"), NodeVersion.UNKNOWN));

            stageExecution = new SqlStageExecution(new QueryId("query"),
                    new MockLocationFactory(),
                    joinPlan,
                    new NodeScheduler(nodeManager, new NodeSchedulerConfig()), new MockRemoteTaskFactory(executor),

Examples of com.facebook.presto.spi.Node

        for (Map.Entry<Node, RemoteTask> entry : tasks1.entrySet()) {
            assertEquals(entry.getValue().getPartitionedSplitCount(), 5);
        }

        // Add new node
        Node additionalNode = new PrestoNode("other4", URI.create("http://127.0.0.1:14"), NodeVersion.UNKNOWN);
        nodeManager.addNode("foo", additionalNode);

        // Schedule next query with 5 splits. Since the new node does not have any splits, all 5 splits are assigned to the new node
        SqlStageExecution sqlStageExecution2 = createSqlStageExecution(nodeScheduler, 5, 5);
        Future future2 = sqlStageExecution2.start();

Examples of com.facebook.presto.sql.tree.Node

        new DefaultTraversalVisitor<Node, Void>()
        {
            @Override
            public Node process(Node node, @Nullable Void context)
            {
                Node result = super.process(node, context);
                nodes.add(node);
                return result;
            }
        }.process(tree, null);
        return nodes.build();

Examples of com.founder.fix.bpmn2extensions.connectormenu.Node

    ConnectormenuFactory.eINSTANCE.eClass();
 
 
    Menu flowConnectorDefinition=ConnectormenuFactory.eINSTANCE.createMenu();

    Node node=ConnectormenuFactory.eINSTANCE.createNode();
    node.setId("1");
   
   
    Node node1=ConnectormenuFactory.eINSTANCE.createNode();
   
    Node node2=ConnectormenuFactory.eINSTANCE.createNode();
   
    node.getNode().add(node1);
    node.getNode().add(node2);
   
    flowConnectorDefinition.getNode().add(node);

Examples of com.gargoylesoftware.htmlunit.javascript.host.Node

                ok = false;
            }
            // If the download was a success, trigger the onload handler.
            if (ok) {
                final Event event = new Event(this, Event.TYPE_LOAD);
                final Node scriptObject = (Node) getScriptObject();
                final PostponedAction action = new PostponedAction(getPage()) {
                    @Override
                    public void execute() throws Exception {
                        scriptObject.executeEvent(event);
                    }
                };
                final String readyState = htmlPage.getReadyState();
                if (READY_STATE_LOADING.equals(readyState)) {
                    htmlPage.addAfterLoadAction(action);

Examples of com.gistlabs.mechanize.document.node.Node

  protected abstract T newRepresentation(Node element);
 
  public T find(String csss) {
    for(Node node : nodes) {
      Node find = node.find(csss);
      if(find!=null)
        return getCachedOrNewRepresentation(node);
    }

    return null;   

Examples of com.github.mustachejava.util.Node

  @Override
  public Node invert(Node node, String text, AtomicInteger position) {
    int start = position.get();
    List<Node> nodes = new ArrayList<Node>();
    Node invert;
    while ((invert = mustache.invert(new Node(), text, position)) != null) {
      nodes.add(invert);
    }
    node.put(name, list(nodes));
    if (appended == null) {
      return node;
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.