Examples of Join


Examples of com.uwyn.drone.protocol.commands.Join

   
    try
    {
      synchronized (mServer)
      {
        mServer.send(new Join(mName, mPassword));
      }
    }
    catch (CoreException e)
    {
      throw new JoinErrorException(this, e);
View Full Code Here

Examples of de.fuberlin.wiwiss.d2rq.algebra.Join

    this.out.println("\t.");
  }

  private void writeLinkTable(RelationName linkTableName) {
    List<Join> keys = schema.foreignKeys(linkTableName, DatabaseSchemaInspector.KEYS_IMPORTED);
    Join join1 = keys.get(0);
    Join join2 = keys.get(1);
    if (!filter.matches(join1.table1()) || !filter.matches(join1.table2()) ||
        !filter.matchesAll(join1.attributes1()) || !filter.matchesAll(join1.attributes2()) ||
        !filter.matches(join2.table1()) || !filter.matches(join2.table2()) ||
        !filter.matchesAll(join2.attributes1()) || !filter.matchesAll(join2.attributes2())) {
      log.info("Skipping link table " + linkTableName);
      return;
    }
    log.info("Generating d2rq:PropertyBridge instance for table " + linkTableName.qualifiedName());
    RelationName table1 = this.schema.getCorrectCapitalization(join1.table2());
    RelationName table2 = this.schema.getCorrectCapitalization(join2.table2());
    boolean isSelfJoin = table1.equals(table2);
    this.out.println("# Table " + linkTableName + (isSelfJoin ? " (n:m self-join)" : " (n:m)"));
    this.out.println(propertyBridgeIRITurtle(linkTableName, "link") + " a d2rq:PropertyBridge;");
    this.out.println("\td2rq:belongsToClassMap " + classMapIRITurtle(table1) + ";");
    this.out.println("\td2rq:property " + vocabularyIRITurtle(linkTableName) + ";");
    this.out.println("\td2rq:refersToClassMap " + classMapIRITurtle(table2) + ";");
    for (Attribute column: join1.attributes1()) {
      Attribute otherColumn = join1.equalAttribute(column);
      this.out.println("\td2rq:join \"" + column.qualifiedName() + " " + Join.joinOperators[join1.joinDirection()] + " " + otherColumn.qualifiedName() + "\";");
    }
    AliasMap alias = AliasMap.NO_ALIASES;
    if (isSelfJoin) {
      RelationName aliasName = new RelationName(
          null, table2.tableName() + "_" + linkTableName.tableName() + "__alias");
      alias = AliasMap.create1(table2, aliasName);
      this.out.println("\td2rq:alias \"" + table2.qualifiedName() +
          " AS " + aliasName.qualifiedName() + "\";");
    }
    for (Attribute column: join2.attributes1()) {
      Attribute otherColumn = join2.equalAttribute(column);
      this.out.println("\td2rq:join \"" + column.qualifiedName() + " " + Join.joinOperators[join2.joinDirection()] + " " + alias.applyTo(otherColumn).qualifiedName() + "\";");
    }
    this.out.println("\t.");
    this.out.println();
    createLinkProperty(linkTableName, table1, table2);
    this.out.flush();
View Full Code Here

Examples of edu.umass.pql.Join

            if (RuntimeCreatorBench.class.getMethods()[i].getName().contains("sumInt"))
                method = RuntimeCreatorBench.class.getMethods()[i];
        }

        PQLFactory.setParallelisationMode(PQLFactory.ParallelisationMode.NONPARALLEL);
        Join p = PQLFactory.Reductionnew Reductor [] {PQLFactory.Reductors.N_DEFAULT_MAP(i0r, i2r, PQLFactory.Reductors.METHOD_ADAPTER(method, i4r, _), o3w) },
                PQLFactory.CONTAINS(o1r, o0w),
                PQLFactory.FIELD(env.v_object[0].getClass(), o0r, o2w),
                PQLFactory.EQ_Int(i1r, i4w),
                PQLFactory.ARRAY_LOOKUP_Int(o2r, _ ,i2w)
                );
View Full Code Here

Examples of er.neo4jadaptor.test.eo.Join

  public void test21_insertJoinEntity_explicit() {
    FirstEntity first = ERXEOControlUtilities.createAndInsertObject(ec, FirstEntity.class);
    SecondEntity second = ERXEOControlUtilities.createAndInsertObject(ec, SecondEntity.class);
   
    // explicit create Join row
    Join join = ERXEOControlUtilities.createAndInsertObject(ec, Join.class);
   
    join.setFirstEntityRelationship(first);
    join.setSecondEntityRelationship(second);
   
    ec.saveChanges();
    ec.invalidateAllObjects();

    NSArray<FirstEntity> results = fetchAll(FirstEntity.ENTITY_NAME);
View Full Code Here

Examples of javax.jcr.query.qom.Join

        Selector s1 = qf.selector(ntBase, SELECTOR_NAME1);
        Selector s2 = qf.selector(testNodeType, SELECTOR_NAME1);
        JoinCondition cond = qf.equiJoinCondition(ntBase, jcrPrimaryType, testNodeType, jcrPrimaryType);
        for (Iterator it = JOIN_TYPES.iterator(); it.hasNext(); ) {
            String joinType = (String) it.next();
            Join join = qf.join(s1, s2, joinType, cond);
            assertTrue("Not a selector source", join.getLeft() instanceof Selector);
            assertTrue("Not a selector source", join.getRight() instanceof Selector);
            assertEquals("Wrong join type", joinType, join.getJoinType());
            assertTrue("Not an EquiJoinCondition", join.getJoinCondition() instanceof EquiJoinCondition);
        }
    }
View Full Code Here

Examples of javax.jcr.query.qom.Join

        // Swap the join sources to normalize all outer joins to left
        if (JCR_JOIN_TYPE_RIGHT_OUTER.equalsIgnoreCase(join.getJoinType())) {
            log.debug(
                    "{} SQL2 RIGHT OUTER JOIN transformed to LEFT OUTER JOIN.",
                    genString(printIndentation));
            Join betterJoin = qomFactory.join(join.getRight(), join.getLeft(),
                    JCR_JOIN_TYPE_LEFT_OUTER, join.getJoinCondition());
            return execute(columns, betterJoin, constraint, orderings, offset,
                    limit, printIndentation);
        }
        JoinMerger merger = JoinMerger.getJoinMerger(join,
View Full Code Here

Examples of javax.jcr.query.qom.Join

        if (source instanceof Selector) {
            Selector selector = (Selector) source;
            return Collections.singletonMap(selector.getSelectorName(),
                    getNodeType(selector));
        } else if (source instanceof Join) {
            Join join = (Join) source;
            Map<String, NodeType> map = new LinkedHashMap<String, NodeType>();
            map.putAll(getSelectorNames(join.getLeft()));
            map.putAll(getSelectorNames(join.getRight()));
            return map;
        } else {
            throw new UnsupportedRepositoryOperationException(
                    "Unknown source type: " + source);
        }
View Full Code Here

Examples of javax.persistence.criteria.Join

    }

    @Override
    public List<Predicate> build(CriteriaBuilder builder, Path<P> path)
    {
        Join join = null;
        if (singular != null)
        {
            join = joinSingular((From) path);
        }
        else if (list != null)
View Full Code Here

Examples of jimm.datavision.source.Join

}

public void testMultipleJoins() throws IOException, FileNotFoundException {
    for (Iterator iter = report.subreports(); iter.hasNext(); ) {
  Subreport s = (Subreport)iter.next();
  s.addJoin(new Join(report.findColumn("office.name"), "=",
         report.findColumn("office.name")));
    }

    // Run report in this thread, not a separate one. Running the
    // report closes the output stream.
View Full Code Here

Examples of lupos.engine.operators.multiinput.join.Join

    }
    // 2. Joins erstellen
    BasicOperator headOperator = null;
    final Iterator<BasicOperator> opIt = operands.iterator();
    if (operands.size() > 1) {
      Join bottomJoin = new IndexJoinWithDuplicateElimination();
      final BasicOperator op1 = opIt.next();
      for(final OperatorIDTuple opID: op1.getSucceedingOperators()){
        opID.getOperator().removePrecedingOperator(op1);
      }
      op1.getSucceedingOperators().clear();
      op1.addSucceedingOperator(new OperatorIDTuple(bottomJoin, 0));
      bottomJoin.addPrecedingOperator(op1);
      final BasicOperator op2 = opIt.next();
      for(final OperatorIDTuple opID: op2.getSucceedingOperators()){
        opID.getOperator().removePrecedingOperator(op2);
      }
      op2.getSucceedingOperators().clear();
      op2.addSucceedingOperator(new OperatorIDTuple(bottomJoin, 1));
      bottomJoin.addPrecedingOperator(op2);
      if(arg!=null){
        bottomJoin.setSucceedingOperator((OperatorIDTuple) arg);
        ((OperatorIDTuple) arg).getOperator().addPrecedingOperator(bottomJoin);
      }
      while (opIt.hasNext()) {
        final Join tempJoin = new IndexJoinWithDuplicateElimination();
        final BasicOperator operand = opIt.next();
        for(final OperatorIDTuple opID: operand.getSucceedingOperators()){
          opID.getOperator().removePrecedingOperator(operand);
        }
        operand.getSucceedingOperators().clear();
        operand.setSucceedingOperator(new OperatorIDTuple(tempJoin, 0));
        tempJoin.addPrecedingOperator(operand);
        for(final OperatorIDTuple opID: bottomJoin.getSucceedingOperators()){
          opID.getOperator().removePrecedingOperator(bottomJoin);
        }
        bottomJoin.getSucceedingOperators().clear();
        bottomJoin.setSucceedingOperator(new OperatorIDTuple(tempJoin, 1));
        tempJoin.addPrecedingOperator(bottomJoin);
        if(arg!=null){
          tempJoin.setSucceedingOperator((OperatorIDTuple) arg);
          ((OperatorIDTuple) arg).getOperator().addPrecedingOperator(tempJoin);
        }
        bottomJoin = tempJoin;
      }
      headOperator = bottomJoin;
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.