org.openrdf.model.Statement Java Examples
The following examples show how to use
org.openrdf.model.Statement.
You can vote up the ones you like or vote down the ones you don't like,
and go to the original project or source file by following the links above each example. You may check out the related API usage on the sidebar.
Example #1
Source File: NTriplesAlternative.java From GeoTriples with Apache License 2.0 | 6 votes |
public void handleStatementIter(Collection<Statement> statements) throws RDFHandlerException { if (!writingStarted) throw new RuntimeException("Document writing has not yet been started"); try { // WARNING if you want to produce blank nodes replace all the .append("<").append(X).append(">"); // with NTriplesUtil.append(st.getSubject(), sb); for(Statement st: statements){ sb .append("<") .append(st.getSubject().toString()) .append("> <") .append(st.getPredicate().toString()) .append("> "); NTriplesUtilNoEscape.append(st.getObject(), sb); sb.append(" .\n"); } } catch (Exception e) { throw new RDFHandlerException(e); } }
Example #2
Source File: BlazeGraphEmbedded.java From tinkerpop3 with GNU General Public License v2.0 | 6 votes |
/** * {@inheritDoc} * * Logs the query at INFO and logs the optimized AST at TRACE. */ @Override protected Stream<Statement> _project( final String queryStr, final String extQueryId) { logQuery(queryStr); return Code.wrapThrow(() -> { final BigdataSailGraphQuery query = (BigdataSailGraphQuery) cxn().prepareGraphQuery(QueryLanguage.SPARQL, queryStr); setMaxQueryTime(query); final UUID queryId = setupQuery(query.getASTContainer(), QueryType.CONSTRUCT, extQueryId); sparqlLog.trace(() -> "optimized AST:\n"+query.optimize()); /* * Result is closed automatically by GraphStreamer. */ final GraphQueryResult result = query.evaluate(); final Optional<Runnable> onClose = Optional.of(() -> finalizeQuery(queryId)); return new GraphStreamer<>(result, onClose).stream(); }); }
Example #3
Source File: RDFDataModule.java From mustard with MIT License | 6 votes |
@Main public DTGraph<String,String> createGraph() { Set<Statement> stmts; if (graphDepth == 0) { // graphDepth == 0, is get the full graph stmts = new HashSet<Statement>(dataset.getFullGraph(inference)); } else { stmts = RDFUtils.getStatements4Depth(dataset, instances, graphDepth, inference); } stmts.removeAll(blackList); if (instances == null) { // No instances supplied, then we do not create instanceNodes graph = RDFUtils.statements2Graph(stmts, RDFUtils.REGULAR_LITERALS); } else { SingleDTGraph g = RDFUtils.statements2Graph(stmts, RDFUtils.REGULAR_LITERALS, instances, false); graph = g.getGraph(); instanceNodes = g.getInstances(); } return graph; }
Example #4
Source File: BigdataNTriplesParserTestCase.java From database with GNU General Public License v2.0 | 6 votes |
public void testNTriplesFile() throws Exception { RDFParser turtleParser = createRDFParser(); turtleParser.setDatatypeHandling(RDFParser.DatatypeHandling.IGNORE); turtleParser.setRDFHandler(new RDFHandlerBase() { public void handleStatement(Statement st) throws RDFHandlerException { if (log.isInfoEnabled()) log.info("Statement: " + st); } }); // Note: This is a local copy. InputStream in = BigdataNTriplesParser.class.getResourceAsStream(NTRIPLES_TEST_FILE); try { turtleParser.parse(in, NTRIPLES_TEST_URL); } catch (RDFParseException e) { fail("Failed to parse N-Triples test document: " + e.getMessage()); } finally { in.close(); } }
Example #5
Source File: SPARQLQueryTest.java From database with GNU General Public License v2.0 | 6 votes |
protected final TupleQueryResult readExpectedTupleQueryResult() throws Exception { TupleQueryResultFormat tqrFormat = QueryResultIO.getParserFormatForFileName(resultFileURL); if (tqrFormat != null) { InputStream in = new URL(resultFileURL).openStream(); try { TupleQueryResultParser parser = QueryResultIO.createParser(tqrFormat); parser.setValueFactory(dataRep.getValueFactory()); TupleQueryResultBuilder qrBuilder = new TupleQueryResultBuilder(); parser.setQueryResultHandler(qrBuilder); parser.parseQueryResult(in); return qrBuilder.getQueryResult(); } finally { in.close(); } } else { Set<Statement> resultGraph = readExpectedGraphQueryResult(); return DAWGTestResultSetUtil.toTupleQueryResult(resultGraph); } }
Example #6
Source File: RMLMappingFactory.java From GeoTriples with Apache License 2.0 | 6 votes |
/** * Extract content literal from a term type resource. * * @param r2rmlMappingGraph * @param termType * @param term * @return * @throws InvalidR2RMLStructureException */ protected static String extractLiteralFromTermMap( CustomSesameDataset r2rmlMappingGraph, Resource termType, Enum term) throws InvalidR2RMLStructureException { URI p = getTermURI(r2rmlMappingGraph, term); List<Statement> statements = r2rmlMappingGraph.tuplePattern(termType, p, null); if (statements.isEmpty()) { return null; } if (statements.size() > 1) { throw new InvalidR2RMLStructureException( "[RMLMappingFactory:extractValueFromTermMap] " + termType + " has too many " + term + " predicate defined."); } String result = statements.get(0).getObject().stringValue(); if (log.isDebugEnabled()) { log.debug("[RMLMappingFactory:extractLiteralFromTermMap] Extracted " + term + " : " + result); } return result; }
Example #7
Source File: ThemeExperiment.java From mustard with MIT License | 6 votes |
private static Map<Long, Map<Boolean, Map<Integer,Pair<SingleDTGraph, List<Double>>>>> createDataSetCache(LargeClassificationDataSet data, long[] seeds, double fraction, int minSize, int maxClasses, int[] depths, boolean[] inference) { Map<Long, Map<Boolean, Map<Integer,Pair<SingleDTGraph, List<Double>>>>> cache = new HashMap<Long, Map<Boolean, Map<Integer,Pair<SingleDTGraph, List<Double>>>>>(); for (long seed : seeds) { cache.put(seed, new HashMap<Boolean, Map<Integer,Pair<SingleDTGraph, List<Double>>>>()); data.createSubSet(seed, fraction, minSize, maxClasses); for (boolean inf : inference) { cache.get(seed).put(inf, new HashMap<Integer,Pair<SingleDTGraph, List<Double>>>()); for (int depth : depths) { System.out.println("Getting Statements..."); Set<Statement> stmts = RDFUtils.getStatements4Depth(tripleStore, data.getRDFData().getInstances(), depth, inf); System.out.println("# Statements: " + stmts.size()); stmts.removeAll(new HashSet<Statement>(data.getRDFData().getBlackList())); System.out.println("# Statements: " + stmts.size() + ", after blackList"); System.out.println("Building Graph..."); SingleDTGraph graph = RDFUtils.statements2Graph(stmts, RDFUtils.REGULAR_LITERALS, data.getRDFData().getInstances(), true); System.out.println("Built Graph with " + graph.getGraph().nodes().size() + ", and " + graph.getGraph().links().size() + " links"); cache.get(seed).get(inf).put(depth, new Pair<SingleDTGraph,List<Double>>(graph, new ArrayList<Double>(data.getTarget()))); } } } return cache; }
Example #8
Source File: BigdataGASEngine.java From database with GNU General Public License v2.0 | 6 votes |
@SuppressWarnings("unchecked") @Override public Iterator<Statement> getEdges(final IGASContext<?, ?, ?> ctx, final Value u, final EdgesEnum edges) { final AbstractTripleStore kb = getKB(); switch (edges) { case NoEdges: return EmptyIterator.DEFAULT; case InEdges: return getEdges(kb, true/* inEdges */, ctx, getIV(u)); case OutEdges: return getEdges(kb, false/* inEdges */, ctx, getIV(u)); case AllEdges: { final IStriterator a = getEdges(kb, true/* inEdges */, ctx, getIV(u)); final IStriterator b = getEdges(kb, false/* outEdges */, ctx, getIV(u)); a.append(b); return a; } default: throw new UnsupportedOperationException(edges.name()); } }
Example #9
Source File: CumulusRDFSailConnection.java From cumulusrdf with Apache License 2.0 | 6 votes |
public CloseableIteration<? extends Statement, QueryEvaluationException> getRangeStatements( final Resource subj, final URI pred, final Literal lowerBound, final boolean lower_equals, final Literal upperBound, final boolean upper_equals, final Literal equals, final boolean reverse) throws QueryEvaluationException { try { return createRangeStatementIterator(subj, pred, lowerBound, lower_equals, upperBound, upper_equals, equals, reverse); } catch (SailException e) { e.printStackTrace(); throw new QueryEvaluationException(e); } }
Example #10
Source File: RepositoryConnectionTest.java From database with GNU General Public License v2.0 | 6 votes |
@Test public void testAddStatement() throws Exception { testCon.add(bob, name, nameBob); assertTrue(NEWLY_ADDED, testCon.hasStatement(bob, name, nameBob, false)); Statement statement = vf.createStatement(alice, name, nameAlice); testCon.add(statement); assertTrue(NEWLY_ADDED, testCon.hasStatement(statement, false)); assertTrue(NEWLY_ADDED, testCon.hasStatement(alice, name, nameAlice, false)); Repository tempRep = new SailRepository(new MemoryStore()); tempRep.initialize(); RepositoryConnection con = tempRep.getConnection(); con.add(testCon.getStatements(null, null, null, false)); assertTrue("Temp Repository should contain newly added statement", con.hasStatement(bob, name, nameBob, false)); con.close(); tempRep.shutDown(); }
Example #11
Source File: RDFUtils.java From mustard with MIT License | 6 votes |
/** * Convert a set of RDF statements into a DTGraph. * There are three possible ways to treat literals, as regular nodes (REGULAR_LITERALS), as unique nodes (i.e. one for each literal even if they are equal) (REPEAT_LITERALS), * or ignore them (NO_LITERALS) * * @param stmts * @param literalOption * @return */ public static DTGraph<String,String> statements2Graph(Set<Statement> stmts, int literalOption) { DTGraph<String,String> graph = new LightDTGraph<String,String>(); Map<String, DTNode<String,String>> nodeMap = new HashMap<String, DTNode<String,String>>(); for (Statement s : stmts) { if (s.getObject() instanceof Literal && literalOption != NO_LITERALS) { if (literalOption == REGULAR_LITERALS) { addStatement(graph, s, false, false, nodeMap); } if (literalOption == REGULAR_SPLIT_LITERALS) { addStatement(graph, s, false, true, nodeMap); } if (literalOption == REPEAT_LITERALS) { addStatement(graph, s, true, false, nodeMap); } if (literalOption == REPEAT_SPLIT_LITERALS) { addStatement(graph, s, true, true, nodeMap); } } else if (!(s.getObject() instanceof Literal)){ addStatement(graph, s, false, false, nodeMap); } } return graph; }
Example #12
Source File: RDFStoreTest.java From database with GNU General Public License v2.0 | 6 votes |
@Test public void testStatementSerialization() throws Exception { Statement st = vf.createStatement(picasso, RDF.TYPE, painter); ByteArrayOutputStream baos = new ByteArrayOutputStream(); ObjectOutputStream out = new ObjectOutputStream(baos); out.writeObject(st); out.close(); ByteArrayInputStream bais = new ByteArrayInputStream(baos.toByteArray()); ObjectInputStream in = new ObjectInputStream(bais); Statement deserializedStatement = (Statement)in.readObject(); in.close(); assertTrue(st.equals(deserializedStatement)); }
Example #13
Source File: ChunkedCommitHandler.java From neo4j-sparql-extension with GNU General Public License v3.0 | 6 votes |
/** * Handles a statement. * * The statements will be added up until chunk size is reached. * After a chunk of statements is added the transaction will be committed * and new transaction will be started. * @param stmnt * @throws RDFHandlerException */ @Override public void handleStatement(Statement stmnt) throws RDFHandlerException { try { // check if triple should be added to a specific graph if (dctx != null) { conn.add(stmnt, dctx); } else { conn.add(stmnt); } // check if chunk size is reached and transaction should be // committed count++; if (count >= size) { count = 0; conn.commit(); conn.begin(); } } catch (RepositoryException ex) { throw new RDFHandlerException(ex); } }
Example #14
Source File: RMLMappingFactory.java From GeoTriples with Apache License 2.0 | 6 votes |
/** * Extract content URIs from a term type resource. * * @return * @throws InvalidR2RMLStructureException */ protected static Set<URI> extractURIsFromTermMap( CustomSesameDataset r2rmlMappingGraph, Resource termType, R2RMLTerm term) throws InvalidR2RMLStructureException { URI p = getTermURI(r2rmlMappingGraph, term); List<Statement> statements = r2rmlMappingGraph.tuplePattern(termType, p, null); if (statements.isEmpty()) { return null; } Set<URI> uris = new HashSet<URI>(); for (Statement statement : statements) { URI uri = (URI) statement.getObject(); log.debug("[RMLMappingFactory:extractURIsFromTermMap] Extracted " + term + " : " + uri.stringValue()); uris.add(uri); } return uris; }
Example #15
Source File: ValueDictionaryBase.java From cumulusrdf with Apache License 2.0 | 6 votes |
@Override public Iterator<Statement> toValueTripleIterator(final Iterator<byte[][]> triples) { return new AbstractIterator<Statement>() { @Override protected Statement computeNext() { while (triples.hasNext()) { final byte[][] ids = triples.next(); try { return getValues(ids[0], ids[1], ids[2]); } catch (DataAccessLayerException exception) { _log.error(MessageCatalog._00093_DATA_ACCESS_LAYER_FAILURE, exception); return endOfData(); } } return endOfData(); } }; }
Example #16
Source File: TestFederatedQuery.java From database with GNU General Public License v2.0 | 6 votes |
/** * Read the expected tuple query result from the specified resource * * @param queryResource * @return * @throws RepositoryException * @throws IOException */ private TupleQueryResult readExpectedTupleQueryResult(final String resultFile) throws Exception { final TupleQueryResultFormat tqrFormat = QueryResultIO.getParserFormatForFileName(resultFile); if (tqrFormat != null) { final InputStream in = TestFederatedQuery.class.getResourceAsStream(TEST_RESOURCE_PATH + resultFile); try { final TupleQueryResultParser parser = QueryResultIO.createParser(tqrFormat); parser.setValueFactory(ValueFactoryImpl.getInstance()); final TupleQueryResultBuilder qrBuilder = new TupleQueryResultBuilder(); parser.setTupleQueryResultHandler(qrBuilder); parser.parse(in); return qrBuilder.getQueryResult(); } finally { in.close(); } } else { final Set<Statement> resultGraph = readExpectedGraphQueryResult(resultFile); return DAWGTestResultSetUtil.toTupleQueryResult(resultGraph); } }
Example #17
Source File: ValueDictionaryBase.java From cumulusrdf with Apache License 2.0 | 6 votes |
@Override public Iterator<byte[][]> toIDTripleIterator(final Iterator<Statement> triples) { return new AbstractIterator<byte[][]>() { @Override protected byte[][] computeNext() { if (!triples.hasNext()) { return endOfData(); } final Statement statement = triples.next(); try { return new byte[][] { getID(statement.getSubject(), false), getID(statement.getPredicate(), true), getID(statement.getObject(), false) }; } catch (final DataAccessLayerException exception) { _log.error(MessageCatalog._00093_DATA_ACCESS_LAYER_FAILURE, exception); return endOfData(); } } }; }
Example #18
Source File: RepositoryConnectionTest.java From database with GNU General Public License v2.0 | 5 votes |
@Test public void testPreparedGraphQuery() throws Exception { testCon.add(alice, name, nameAlice, context2); testCon.add(alice, mbox, mboxAlice, context2); testCon.add(context2, publisher, nameAlice); testCon.add(bob, name, nameBob, context1); testCon.add(bob, mbox, mboxBob, context1); testCon.add(context1, publisher, nameBob); StringBuilder queryBuilder = new StringBuilder(128); queryBuilder.append(" prefix foaf: <" + FOAF_NS + ">"); queryBuilder.append(" construct "); queryBuilder.append(" where { ?s foaf:name ?name . ?s foaf:mbox ?mbox . }"); GraphQuery query = testCon.prepareGraphQuery(QueryLanguage.SPARQL, queryBuilder.toString()); query.setBinding(NAME, nameBob); GraphQueryResult result = query.evaluate(); try { assertThat(result, is(notNullValue())); assertThat(result.hasNext(), is(equalTo(true))); while (result.hasNext()) { Statement st = result.next(); URI predicate = st.getPredicate(); assertThat(predicate, anyOf(is(equalTo(name)), is(equalTo(mbox)))); Value object = st.getObject(); if (name.equals(predicate)) { assertEquals("unexpected value for name: " + object, nameBob, object); } else { assertThat(predicate, is(equalTo(mbox))); assertEquals("unexpected value for mbox: " + object, mboxBob, object); } } } finally { result.close(); } }
Example #19
Source File: ComputationTimeLargeExperiment.java From mustard with MIT License | 5 votes |
private static void computeGraphStatistics(RDFDataSet tripleStore, ClassificationDataSet ds, boolean[] inference, int[] depths) { Map<Boolean, Map<Integer, Pair<Double, Double>>> stats = new HashMap<Boolean, Map<Integer, Pair<Double, Double>>>(); for (boolean inf : inference) { stats.put(inf, new HashMap<Integer, Pair<Double, Double>>()); for (int depth : depths) { Set<Statement> st = RDFUtils.getStatements4Depth(tripleStore, ds.getRDFData().getInstances(), depth, inf); st.removeAll(ds.getRDFData().getBlackList()); DTGraph<String,String> graph = RDFUtils.statements2Graph(st, RDFUtils.REGULAR_LITERALS); List<DTNode<String,String>> instanceNodes = RDFUtils.findInstances(graph, ds.getRDFData().getInstances()); graph = RDFUtils.simplifyInstanceNodeLabels(graph, instanceNodes); GraphList<DTGraph<String,String>> graphs = RDFUtils.getSubGraphs(graph, instanceNodes, depth); double v = 0; double e = 0; for (DTGraph<String,String> g : graphs.getGraphs()) { v += g.nodes().size(); e += g.links().size(); } v /= graphs.numInstances(); e /= graphs.numInstances(); stats.get(inf).put(depth, new Pair<Double,Double>(v,e)); } } for (boolean k1 : stats.keySet()) { System.out.println("Inference: " + k1); for (int k2 : stats.get(k1).keySet()) { System.out.println("Depth " + k2 + ", vertices: " + (stats.get(k1).get(k2).getFirst()) + " , edges: " + (stats.get(k1).get(k2).getSecond())); } } }
Example #20
Source File: SimpleGraphFeaturesAMExperiment.java From mustard with MIT License | 5 votes |
private static Map<Long, Map<Boolean, Map<Integer,Pair<SingleDTGraph, List<Double>>>>> createDataSetCache(LargeClassificationDataSet data, long[] seeds, double fraction, int minSize, int maxClasses, int[] depths, boolean[] inference) { Map<Long, Map<Boolean, Map<Integer,Pair<SingleDTGraph, List<Double>>>>> cache = new HashMap<Long, Map<Boolean, Map<Integer,Pair<SingleDTGraph, List<Double>>>>>(); for (long seed : seeds) { cache.put(seed, new HashMap<Boolean, Map<Integer,Pair<SingleDTGraph, List<Double>>>>()); data.createSubSet(seed, fraction, minSize, maxClasses); for (boolean inf : inference) { cache.get(seed).put(inf, new HashMap<Integer,Pair<SingleDTGraph, List<Double>>>()); for (int depth : depths) { System.out.println("Getting Statements..."); Set<Statement> stmts = RDFUtils.getStatements4Depth(tripleStore, data.getRDFData().getInstances(), depth, inf); System.out.println("# Statements: " + stmts.size()); stmts.removeAll(new HashSet<Statement>(data.getRDFData().getBlackList())); System.out.println("# Statements: " + stmts.size() + ", after blackList"); System.out.println("Building Graph..."); SingleDTGraph graph = RDFUtils.statements2Graph(stmts, RDFUtils.REGULAR_LITERALS, data.getRDFData().getInstances(), true); System.out.println("Built Graph with " + graph.getGraph().nodes().size() + ", and " + graph.getGraph().links().size() + " links"); cache.get(seed).get(inf).put(depth, new Pair<SingleDTGraph,List<Double>>(graph, new ArrayList<Double>(data.getTarget()))); } } } return cache; }
Example #21
Source File: BigdataStoreTest.java From database with GNU General Public License v2.0 | 5 votes |
@Override protected void testValueRoundTrip(Resource subj, URI pred, Value obj) throws Exception { con.begin(); con.addStatement(subj, pred, obj); con.commit(); CloseableIteration<? extends Statement, SailException> stIter = con .getStatements(null, null, null, false); try { assertTrue(stIter.hasNext()); Statement st = stIter.next(); assertEquals(subj, st.getSubject()); assertEquals(pred, st.getPredicate()); assertEquals(obj, st.getObject()); assertTrue(!stIter.hasNext()); } finally { stIter.close(); } final String query = "SELECT ?S ?P ?O WHERE { ?S ?P ?O filter(?P = <" + pred.stringValue() + ">) }"; CloseableIteration<? extends BindingSet, QueryEvaluationException> iter; iter = evaluate(query, con); try { assertTrue(iter.hasNext()); BindingSet bindings = iter.next(); assertEquals(subj, bindings.getValue("S")); assertEquals(pred, bindings.getValue("P")); assertEquals(obj, bindings.getValue("O")); assertTrue(!iter.hasNext()); } finally { iter.close(); } }
Example #22
Source File: RepositoryConnectionTest.java From database with GNU General Public License v2.0 | 5 votes |
@Test public void testSimpleGraphQuery() throws Exception { testCon.add(alice, name, nameAlice, context2); testCon.add(alice, mbox, mboxAlice, context2); testCon.add(context2, publisher, nameAlice); testCon.add(bob, name, nameBob, context1); testCon.add(bob, mbox, mboxBob, context1); testCon.add(context1, publisher, nameBob); StringBuilder queryBuilder = new StringBuilder(128); queryBuilder.append(" prefix foaf: <" + FOAF_NS + ">"); queryBuilder.append(" construct "); queryBuilder.append(" where { ?s foaf:name ?name . ?s foaf:mbox ?mbox . }"); GraphQueryResult result = testCon.prepareGraphQuery(QueryLanguage.SPARQL, queryBuilder.toString()).evaluate(); try { assertThat(result, is(notNullValue())); assertThat(result.hasNext(), is(equalTo(true))); while (result.hasNext()) { Statement st = result.next(); if (name.equals(st.getPredicate())) { assertThat(st.getObject(), anyOf(is(equalTo((Value)nameAlice)), is(equalTo((Value)nameBob)))); } else { assertThat(st.getPredicate(), is(equalTo(mbox))); assertThat(st.getObject(), anyOf(is(equalTo((Value)mboxAlice)), is(equalTo((Value)mboxBob)))); } } } finally { result.close(); } }
Example #23
Source File: StressTest_REST_MultiTenancy.java From database with GNU General Public License v2.0 | 5 votes |
private void loadStatements(final String namespace, final int nstatements) throws Exception { final Collection<Statement> stmts = new ArrayList<>(nstatements); for (int i = 0; i < nstatements; i++) { stmts.add(generateTriple()); } log.warn(String.format("Loading package into %s namespace...", namespace)); m_mgr.getRepositoryForNamespace(namespace).add(new RemoteRepository.AddOp(stmts)); log.warn(String.format("Loading package into %s namespace done", namespace)); }
Example #24
Source File: ModelUtil.java From database with GNU General Public License v2.0 | 5 votes |
/** * Compares two models, defined by two statement collections, and returns * <tt>true</tt> if they are equal. Models are equal if they contain the same * set of statements. Blank node IDs are not relevant for model equality, * they are mapped from one model to the other by using the attached * properties. */ public static boolean equals(Set<? extends Statement> model1, Set<? extends Statement> model2) { // Compare the number of statements in both sets if (model1.size() != model2.size()) { return false; } return isSubsetInternal(model1, model2); }
Example #25
Source File: XPathProcessor.java From GeoTriples with Apache License 2.0 | 5 votes |
public WorkerPerformOnNode(RMLPerformer performer, Resource subject, Node n, SesameDataSet dataset, TriplesMap parentTriplesMap, TriplesMap map, List<Statement> statements2) { this.performer = performer; this.subject = subject; this.n = n; this.dataset = dataset; this.parentTriplesMap = parentTriplesMap; this.map = map; this.statements=statements2; }
Example #26
Source File: BigdataSailRemoteRepositoryConnectionTest.java From database with GNU General Public License v2.0 | 5 votes |
@Test public void testGetStatements() throws RepositoryException { final RepositoryResult<Statement> stmts = con.getStatements(s, p, o, includeInferred, c); try { assertEquals(EncodeDecodeValue.encodeValue(s), remote.data.opts.getRequestParam("s")); assertEquals(EncodeDecodeValue.encodeValue(p), remote.data.opts.getRequestParam("p")); assertEquals(EncodeDecodeValue.encodeValue(o), remote.data.opts.getRequestParam("o")); assertEquals(EncodeDecodeValue.encodeValue(c), remote.data.opts.getRequestParam("c")); assertEquals(Boolean.toString(includeInferred), remote.data.opts.getRequestParam(RemoteRepositoryDecls.INCLUDE_INFERRED)); } finally { stmts.close(); } }
Example #27
Source File: RDFSparqlDataSet.java From mustard with MIT License | 5 votes |
@Override public List<Statement> getStatements(Resource subject, URI predicate, Value object, boolean allowInference) { for (String nameSpace : nameSpaces) { if ((subject != null && subject.toString().startsWith(nameSpace)) || (object != null && object.toString().startsWith(nameSpace))) { if (!fake) { List<Statement> res = super.getStatements(subject, predicate, object, allowInference); //System.out.println("Querying external dataset " + super.getLabel() + ", got: " + res.size() + " statements."); return res; } else { try { FileWriter out = new FileWriter(logFile, true); if (subject != null) { out.write(subject.toString()); out.write("\n"); } out.close(); } catch (Exception e) { e.printStackTrace(); } return new ArrayList<Statement>(); } } } return new ArrayList<Statement>(); }
Example #28
Source File: BackgroundGraphResult.java From database with GNU General Public License v2.0 | 5 votes |
@Override public void handleStatement(final Statement st) throws RDFHandlerException { namespacesReady.countDown(); if (closed) throw new RDFHandlerException("Result closed"); try { queue.put(st); } catch (InterruptedException e) { throw new RDFHandlerException(e); } }
Example #29
Source File: CRUDTest.java From anno4j with Apache License 2.0 | 5 votes |
/** * Returns all statements that are present in any context of a repository having the specified subject, predicate and/or object. * @param connection A connection to the repository to query. * @param subject The subject the returned triples should have or null for any subject. * @param predicate The predicate the returned triples should have or null for any predicate. * @param object The object the returned triples should have or null for any object. * @return Returns the set of all triples present in the repository having the desired spo-structure. * @throws RepositoryException Thrown if an error occurs while querying the repository. */ private Collection<Statement> getStatements(RepositoryConnection connection, Resource subject, URI predicate, Value object) throws RepositoryException { // Query the repository: RepositoryResult<Statement> result = connection.getStatements(subject, predicate, object, false); // Fetch all statements from the result: Collection<Statement> statements = new HashSet<>(); while (result.hasNext()) { statements.add(result.next()); } return statements; }
Example #30
Source File: SesameRepositoryImpl.java From sparql-playground with GNU General Public License v2.0 | 5 votes |
public void clearData() { try { RepositoryResult<Statement> statements = rep.getConnection().getStatements(null, null, null, true); rep.getConnection().remove(statements); } catch (RepositoryException e) { e.printStackTrace(); throw new SparqlTutorialException(e); } }