Uses of Class
com.semedy.reasoner.api.reasoning.SemReasonerException
Packages that use SemReasonerException
Package
Description
-
Uses of SemReasonerException in com.semedy.reasoner.api.builtin
Subclasses of SemReasonerException in com.semedy.reasoner.api.builtinMethods in com.semedy.reasoner.api.builtin that throw SemReasonerExceptionModifier and TypeMethodDescriptionbooleanAbstractConnector.eval()Create queries from available restrictions.voidAggregation.evaluate(BuiltinReceiver receiver) Evaluate the aggregation.booleanGiven the input tuple and the instantiated arguments.voidRelationalBuiltin.evaluate(long[] input, BitSet grounds, BuiltinReceiver receiver) Evaluate the built-in given the input tuple.booleanvoidinitialize the builtinabstract voidinitialize the built-invoidvoidAbstractConnector.input(long[] input) voidAggregation.input(long[] input) feed aggregation with input tuplevoidConnector.input(long[] input) Feed the built-in with an input tuple.booleanFilterBuiltin.isTrue(long[] input) is built-in true for given argumentsvoidSensorBuiltin.receiveEncodedEvent(Object[] tuple) receives an event with already coded values (longs)
triggers reasoning with this new infovoidSensorBuiltinSingleValue.receiveEncodedEvent(Object[] tuple) receives an event with already coded values (longs)
retracts the previous event
triggers reasoning with this new infovoidSensorBuiltin.receiveEvent(Object[] tuple) receives an event from an external system/sensor and
triggers reasoning with this new infovoidSensorBuiltinSingleValue.receiveEvent(Object[] tuple) receives an event from an external system/sensor and
retracts the previous event
triggers reasoning with this new infovoidSensorBuiltin.retractEncodedEvent(Object[] tuple) retracts an event with already coded values (longs)
triggers reasoning with this new infovoidSensorBuiltin.retractEvent(Object[] tuple) withdraws an event from an external system/sensor and triggers reasoning with this new infovoidBuiltinReceiver.send(long[] buffer) gets the results of a built-in.voidBuiltinReceiver.send(TupleBuffer buffer) gets the results of a built-in.voidCollectorBuiltinReceiver.send(long[] buffer) voidCollectorBuiltinReceiver.send(TupleBuffer buffer) voidstart feeding the aggregation with input.voidAbstractConnector.stop()voidAggregation.stop()stop feeding the aggregation with inputabstract voidCachedConnector.stop()voidConnector.stop()stop feeding the built-in with input values -
Uses of SemReasonerException in com.semedy.reasoner.api.core
Methods in com.semedy.reasoner.api.core that throw SemReasonerExceptionModifier and TypeMethodDescriptionbooleanJSONDeductiveDatabase.addJsonObject(org.json.JSONObject json) add a JSON objectbooleanJSONDeductiveDatabase.addJsonObject(org.json.JSONObject json, Object module) add a JSON objectbooleanJSONDeductiveDatabase.addJsonObjects(String objects) add a set of JSON objects, given as a Json array in a string.booleanJSONDeductiveDatabase.addJsonObjects(String objects, Object module) add a set of JSON objects, given as a Json array in a string.booleanJSONDeductiveDatabase.addJsonObjects(Collection<org.json.JSONObject> objects) add a set of JSON objects.booleanJSONDeductiveDatabase.addJsonObjects(Collection<org.json.JSONObject> objects, Object module) add a set of JSON objects.booleanJSONDeductiveDatabase.addJsonObjects(org.json.JSONArray objects) add a set of JSON objects given in a Json arraybooleanJSONDeductiveDatabase.addJsonObjects(org.json.JSONArray objects, String module) add a set of JSON objects given in a Json arraybooleanadd a rule to the deductive database.booleanadd a rule to the deductive database.booleanDeductiveDatabase.addRules(Collection<Rule> rules, boolean parsed) Add rules to the deductive database.voidDeductiveDatabase.addRulesAndFacts(String rulesAndFacts) add rules and facts from textvoidDeductiveDatabase.applyChangeSet(List<String> paths) Applies changes to the extensional database.
During this operation the to be modified predicates
are read locked.voidcreate a backup for the databasebooleanCore.checkSanity()voidCore.delete()deletes all resources (files)voidMaterializationReceiver.evaluationFinished()After finishing the evaluation the buffered results (either in a main memory relation or in a file)
are stored in the edb.voidMaterializationReceiver.evaluationFinished(long querykey) After finishing the evaluation the buffered results (either in a main memory relation or in a file)
are stored in the edb.voidStoreEventResultReceiver.evaluationFinished()After finishing the evaluation the buffered results (either in a main memory relation or in a file)
are stored in the edb.voidStoreEventResultReceiver.evaluationFinished(long querykey) After finishing the evaluation the buffered results (either in a main memory relation or in a file)
are stored in the edb.voidDeductiveDatabase.export(InterruptFlag interrupt, List<String> predicates, String resultdirectory) bulk export of facts for predicates to raw files in result directoryvoidJSONDeductiveDatabase.exportJson(String path, Set<String> excludedProperties) Export jsons into filevoidJSONDeductiveDatabase.exportJSONSchemas(Writer writer, boolean inherit) export OO-Logic classes as Json Schemas.voidJSONDeductiveDatabase.exportJSONSchemas(String path, boolean inherit) export OO-Logic classes as Json Schemas.voidDeductiveDatabase.exportNQuads(Writer writer, String iri) export of facts as N-Quads.voidDeductiveDatabase.exportNQuads(String resultpath, String iri) export of facts as N-QuadsvoidDeductiveDatabase.exportOOLogic(InterruptFlag interrupt, Writer writer, String module) export of facts and rules for predicates to file in OO-logic into a module.voidDeductiveDatabase.exportOOLogic(InterruptFlag interrupt, String resultpath, String module) export of facts and rules for predicates to file in OO-logic into a module.voidDeductiveDatabase.exportOOLogic(InterruptFlag interrupt, List<Filter> filters, Writer writer, String module) export of facts and rules for predicates to file in OO-logic into a module.voidDeductiveDatabase.exportOOLogic(InterruptFlag interrupt, List<Filter> filter, String resultpath, String module) export of facts and rules for predicates to file in OO-logic into a module.voidDeductiveDatabase.exportRules(Writer writer) store all rules in file given by file pathvoidDeductiveDatabase.exportRules(String filepath, boolean append) store all rules in file given by file pathResultBuffer.get(int index) Get object at argument indexGet object with variable name.JSONDeductiveDatabase.getAvailableIdentifiers(List<String> identifiers) Which of the given json identifiers are there?JSONDeductiveDatabase.getAvailableIdentifiers(List<String> identifiers, Configuration config, Properties builtinConfig) Which of the given json identifiers are there?JSONDeductiveDatabase.getAvailableIdentifiers(List<String> identifiers, String module, Configuration config, Properties builtinConfig) Which of the given json identifiers are there?JSONDeductiveDatabase.getJSONSchemas(boolean inherit) get OO-Logic classes as Json Schemas.Core.getPartitioningLiterals()get partitioning literalsDeductiveDatabase.getRuleById(String ruleIdentifier) get a rule by its rule identifierDeductiveDatabase.getRules()get all rulesorg.json.JSONObjectJSONDeductiveDatabase.getSchema(String schemaid, Configuration config, Properties builtinConfig) get schema with id schemaidJSONDeductiveDatabase.introspectionQueryGraphQL(String graphQLQuery, String module, String variables, Configuration config, Properties builtinConfig) booleanJSONDeductiveDatabase.isIdentifierAvailable(String identifier) Is this identifier for a json object there?booleanJSONDeductiveDatabase.isIdentifierAvailable(String identifier, Configuration config, Properties builtinConfig) Is this identifier for a json object there?booleanJSONDeductiveDatabase.isIdentifierAvailable(String identifier, String module, Configuration config, Properties builtinConfig) Is this identifier for a json object there?voidload files from file path
path can be a directory or a single file
files are distinguished by their endings:
.raw, .raw.zip, .rls, .fctvoidload files from file paths
files are distinguished by their endings:
.raw, .raw.zip, .rls, .fctvoidImport from a json filesvoidImport from a list of json filesvoidDeductiveDatabase.loadByStream(InputStream in, InputStream companionstream, String format) load facts by stream. format is either the file format like raw,json,nq etc.voidJSONDeductiveDatabase.loadByStream(InputStream in, InputStream companionstream, String format) load facts by stream.voidDeductiveDatabase.loadPredicates(InputStream input) Load facts and/or rules in predicate format from an input stream.booleanDeductiveDatabase.longTransactionBegin()start a long transaction
If a long transaction is already running false is returnedbooleanDeductiveDatabase.longTransactionCommit()commit a long transactionvoidDeductiveDatabase.longTransactionRollback()discard all changesvoidDeductiveDatabase.materializeQueries(InterruptFlag interruptFlag, String squeries, ReasoningMonitor monitor) Materialize queries.voidDeductiveDatabase.materializeQueries(InterruptFlag interruptFlag, String squeries, ReasoningMonitor monitor, Configuration config, Properties builtinConfig) Materialize queries.voidDeductiveDatabase.materializeQueries(InterruptFlag interruptFlag, List<Rule> queries, ReasoningMonitor monitor) Materialize queries.voidDeductiveDatabase.materializeQueries(InterruptFlag interruptFlag, List<Rule> queries, ReasoningMonitor monitor, Configuration config, Properties builtinConfig) Materialize queries.voidStreamReasoningDB.materializeQueries(InterruptFlag interruptFlag, String squeries, ReasoningMonitor monitor) Materialize queries.voidStreamReasoningDB.materializeQueries(InterruptFlag interruptFlag, String squeries, ReasoningMonitor monitor, Configuration config, Properties builtinConfig) Materialize queries.voidStreamReasoningDB.materializeQueries(InterruptFlag interruptFlag, List<Rule> queries, ReasoningMonitor monitor) Materialize queries.voidStreamReasoningDB.materializeQueries(InterruptFlag interruptFlag, List<Rule> queries, ReasoningMonitor monitor, Configuration config, Properties builtinConfig) Materialize queries.DeductiveDatabase.query(InterruptFlag interruptFlag, Rule query, int maxNumberOfResults, ReasoningMonitor monitor) Pose a query.DeductiveDatabase.query(InterruptFlag interruptFlag, Rule query, int maxNumberOfResults, ReasoningMonitor monitor, Configuration config, Properties builtinConfig) Pose a query.DeductiveDatabase.query(InterruptFlag interruptFlag, String query, int maxNumberOfResults, Configuration config, Properties builtinConfig) Pose a query.DeductiveDatabase.query(InterruptFlag interruptFlag, String query, int maxNumberOfResults, ReasoningMonitor monitor) Pose a query.DeductiveDatabase.query(InterruptFlag interruptFlag, String query, int maxNumberOfResults, ReasoningMonitor monitor, Configuration config, Properties builtinConfig) Pose a query.DeductiveDatabase.query(InterruptFlag interruptFlag, String query, Properties builtinConfig) Pose a query.DeductiveDatabase.query(InterruptFlag interruptFlag, List<Rule> queries, int maxNumberOfResults, ReasoningMonitor monitor) Pose a query and several rulesDeductiveDatabase.query(InterruptFlag interruptFlag, List<Rule> queries, int maxNumberOfResults, ReasoningMonitor monitor, Configuration config, Properties builtinConfig) Pose a query and several rulesDeductiveDatabase.query(InterruptFlag interruptFlag, List<Rule> queries, int maxNumberOfResults, ReasoningMonitor monitor, ExtensionalDB[] additionalEDBs, IntensionalDB[] additionalIDBs, boolean skipAnswers, Configuration config, Properties builtinConfig) Pose a query and several rules.TripleCache.query(DeductiveDatabase ddb, String ooquery, int maxNumberOfResults) Retrieve triples using an OO-logic query.TripleCache.query(DeductiveDatabase ddb, String ooquery, int maxNumberOfResults, boolean withCodes) Retrieve triples using an OO-logic query.List<org.json.JSONObject>JSONDeductiveDatabase.queryJsonObjects(String ooquery) Query JSON Objects using an OO-logic query.List<org.json.JSONObject>JSONDeductiveDatabase.queryJsonObjects(String ooquery, String module) Query JSON Objects using an OO-logic query.List<org.json.JSONObject>JSONDeductiveDatabase.queryJsonObjects(String ooquery, String module, Configuration config, Properties builtinConfig) Query JSON Objects using an OO-logic query.List<org.json.JSONObject>JSONDeductiveDatabase.queryJsonObjects(String ooquery, Properties builtinProperties) Query JSON Objects using an OO-logic query.List<org.json.JSONObject>JSONDeductiveDatabase.queryJsonObjects(Collection<String> identifiers) query JSON objects using the json identifiers (@id) in module
Json objects can be derivedList<org.json.JSONObject>JSONDeductiveDatabase.queryJsonObjects(Collection<String> identifiers, Configuration config, Properties builtinConfig) query JSON objects using the json identifiers (@id) in module
Json objects can be derivedList<org.json.JSONObject>JSONDeductiveDatabase.queryJsonObjects(Collection<String> identifiers, Object module, Configuration config, Properties builtinConfig) query JSON objects using the json identifiers (@id) in module
Json objects can be derivedorg.json.JSONObjectJSONDeductiveDatabase.queryJsonObjectsByGraphQL(String graphQLQuery, String module, String variables, Configuration config, Properties builtinConfig) Query JSON Objects using a GraphQL query.booleanEventResultReceiver.receiveRelation(ReasoningRelation tuples) abstract voidEventResultReceiver.receiveResult(long[] result) a new result has been receivedabstract voidEventResultReceiver.receiveResult(TupleBuffer result) a new result has been receivedvoidMaterializationReceiver.receiveResult(long[] tuple) Receive a new result as a tuple of codes.booleanMaterializationReceiver.receiveTuple(int tuple) voidStreamReasoningDB.registerQueries(InterruptFlag interruptFlag, String queries, ReasoningMonitor monitor, List<EventResultReceiver> receiver) Register a set of queries for stream reasoning.voidStreamReasoningDB.registerQueries(InterruptFlag interruptFlag, String queries, ReasoningMonitor monitor, List<EventResultReceiver> receiver, Properties builtinConfig) Register a set of queries for stream reasoning.voidStreamReasoningDB.registerQueries(InterruptFlag interruptFlag, List<Rule> queries, ReasoningMonitor monitor, List<EventResultReceiver> receiver) Register a set of queries for stream reasoning.voidStreamReasoningDB.registerQueries(InterruptFlag interruptFlag, List<Rule> queries, ReasoningMonitor monitor, List<EventResultReceiver> receiver, Properties builtinConfig) Register a set of queries for stream reasoning.booleanDeductiveDatabase.removeFactEncoded(Literal L) Remove a fact from the deductive database.booleanDeductiveDatabase.removeFactsEncoded(Collection<Literal> facts) Remove facts from the deductive database.booleanJSONDeductiveDatabase.removeJsonObject(String identifier) Json object with given id (@id) is deletedbooleanJSONDeductiveDatabase.removeJsonObject(String identifier, Configuration config, Properties builtinConfig) Json object with given id (@id) is deletedbooleanJSONDeductiveDatabase.removeJsonObjects(Collection<String> identifiers) Json objects with given ids (@id) are deletedbooleanJSONDeductiveDatabase.removeJsonObjects(Collection<String> identifiers, Configuration config, Properties builtinConfig) Json objects with given ids (@id) are deletedbooleanJSONDeductiveDatabase.removeJsonObjects(Collection<String> identifiers, String module, Configuration config, Properties builtinConfig) Json objects with given ids (@id) are deletedbooleanDeductiveDatabase.removeRuleById(String id) remove a rule identified by the unique id.booleanDeductiveDatabase.removeRules(Collection<Rule> rules) Remove rules from the deductive database.voidDeductiveDatabase.removeRulesAndFacts(String rulesAndFacts) remove rules and facts from textvoidCore.reOpen()reopen a coreJavaDeductiveDatabase.retrieveJavaObjects(JavaObject object, String conditions) Retrieve JavaObjects of class A.JavaDeductiveDatabase.retrieveJavaObjects(JavaObject object, String conditions, Configuration config, Properties builtinConfig) Retrieve JavaObjects of class A.org.json.JSONObjectJSONDeductiveDatabase.retrieveJsonObject(String identifier, Configuration config, Properties builtinConfig) retrieve JSON object using the json identifier (@id)List<org.json.JSONObject>JSONDeductiveDatabase.retrieveJsonObjects(String ooquery) Retrieve JSON Objects using an OO-logic query and a module.List<org.json.JSONObject>JSONDeductiveDatabase.retrieveJsonObjects(String ooquery, Configuration config, Properties builtinConfig) Retrieve JSON Objects using an OO-logic query.List<org.json.JSONObject>JSONDeductiveDatabase.retrieveJsonObjects(String ooquery, Properties builtinProperties) Retrieve JSON Objects using an OO-logic query and a module.List<org.json.JSONObject>JSONDeductiveDatabase.retrieveJsonObjects(Collection<String> identifiers) retrieve JSON objects using the json identifiers (@id)List<org.json.JSONObject>JSONDeductiveDatabase.retrieveJsonObjects(Collection<String> identifiers, boolean initializeTransaction) retrieve JSON objects using the json identifiers (@id)List<org.json.JSONObject>JSONDeductiveDatabase.retrieveJsonObjects(Collection<String> identifiers, boolean initializeTransaction, Properties builtinConfig) retrieve JSON objects using the json identifiers (@id)List<org.json.JSONObject>JSONDeductiveDatabase.retrieveJsonObjects(Collection<String> identifiers, Configuration config, Properties builtinConfig) retrieve JSON objects using the json identifiers (@id)List<org.json.JSONObject>JSONDeductiveDatabase.retrieveJsonObjects(Collection<String> identifiers, Configuration config, Properties builtinConfig, boolean initializeTransaction) retrieve JSON objects using the json identifiers (@id)JSONCache.retrieveJsons(JSONDeductiveDatabase jdb, String ooquery, int maxNumberOfResults, Properties builtinConfig) Retrieve JSON Objects as strings using an OO-logic query.JSONDeductiveDatabase.retrieveJsons(String ooquery, int maxNumberOfResults, Configuration config, Properties builtinConfig) Retrieve JSON Objects using an OO-logic query.JSONDeductiveDatabase.retrieveJsons(String ooquery, Configuration config, Properties builtinConfig) Retrieve JSON Objects using an OO-logic query.List<org.json.JSONObject>JSONDeductiveDatabase.retrieveTuples(String query, Configuration config, Properties builtinConfig) Retrieve tuples (variable substitutions) for a given query
E.g. query ?voidCore.shutdown()Shutdown this deductive database instance (and closes the core).voidCore.slowLoadMixed(InputStream input) Loads from an input stream facts and rules in usual predicate syntax.voidCore.slowLoadMixedFiles(List<String> files) Loads files for facts and rules in usual predicate syntax.MaterializationReceiver.substitute(Object t, Object[] substitutions) Object[]ResultBuffer.toArray()get an array of result objectsvoidDeductiveDatabase.transactionBegin()start a transactionvoidJavaDeductiveDatabase.transactionBegin()voidJSONDeductiveDatabase.transactionBegin()start a transactionvoidDeductiveDatabase.transactionCommit()commit all modificationsvoidJavaDeductiveDatabase.transactionCommit()voidJSONDeductiveDatabase.transactionCommit()commit transactionvoidDeductiveDatabase.transactionRollback()discard all changesvoidJavaDeductiveDatabase.transactionRollback()voidJSONDeductiveDatabase.transactionRollback()rollback transactionbooleanCore.tryShutdown()Tries to shutdown this deductive database instance (and closes the core).voidMaterializationReceiver.tuplesFinished(boolean isBottomUp) booleanJSONDeductiveDatabase.validateJsonObjects(List<org.json.JSONObject> jsons, String schemaid) Validate json objects against a stored schema with @id "schema".
Returns true if the schema was available and it has been successfully validated.booleanJSONDeductiveDatabase.validateJsonObjects(List<org.json.JSONObject> jsons, String schemaid, Configuration config, Properties builtinConfig) Validate json objects against a stored schema with @id "schema".
Returns true if the schema was available and it has been successfully validated.voidJSONDeductiveDatabase.validateJsonObjects(List<org.json.JSONObject> jsons, org.json.JSONObject schema, Properties builtinConfig) Validate json objects against a schema.Constructors in com.semedy.reasoner.api.core that throw SemReasonerExceptionModifierConstructorDescriptionCore()Core(Configuration configuration) DeductiveDatabase(Core core) JavaDeductiveDatabase(Core core) JSONDeductiveDatabase(Core core) StreamReasoningDB(Core core) create a new stream reasoning database -
Uses of SemReasonerException in com.semedy.reasoner.api.edb
Subclasses of SemReasonerException in com.semedy.reasoner.api.edbModifier and TypeClassDescriptionclassclassclassMethods in com.semedy.reasoner.api.edb that throw SemReasonerExceptionModifier and TypeMethodDescriptionvoidExtensionalDB.addRelation(String pname, Relation T) add a whole relation R to a predicatebooleanExtensionalDB.addTuple(String predicate, TupleBuffer tuple) add tuple to edb.voidcreate a backup for the extensional databasevoidExtensionalDB.backupOld(String backupfile, SymbolTable symbolTable) Deprecated.voidExtensionalDB.bulkExport(InterruptFlag interrupt, List<Filter> filters, String resultdirectory, SymbolTable symbolTable) Bulk export of facts for predicate symbols to raw files in result directoryvoidExtensionalDB.bulkLoadFiles(List<File>[] files, Map<String, Long> counts, Map<String, String> indexToPredicates, String tempdir, SymbolTable symbols) voidvoidExtensionalDB.createIndex(SymbolTable symbols, long propCode) create indices for propertyExtensionalDB.createSchemas(SymbolTable symbols) Create a cache for the hierarchyvoidExtensionalDB.exportNQuads(List<String> predicates, Writer writer, SymbolTable symbolTable, String iri) export of facts for predicate symbols to N-Quads filevoidExtensionalDB.exportOOLogic(InterruptFlag interrupt, List<Filter> filters, Writer writer, SymbolTable symbolTable) export of facts for predicate symbols to OO-logic filevoidExtensionalDB.exportOOLogic(InterruptFlag interrupt, List<Filter> filters, Writer writer, SymbolTable symbolTable, String module) export of facts for predicate symbols to OO-logic file.voidExtensionalDB.exportOOLogic(InterruptFlag interrupt, List<Filter> filters, String resultFile, SymbolTable symbolTable) export of facts for predicate symbols to OO-logic filevoidExtensionalDB.exportOOLogic(InterruptFlag interrupt, List<Filter> filters, String resultFile, SymbolTable symbolTable, String module) export of facts for predicate symbols to OO-logic file.voidLoaderProvider.load(Collection<String> paths, SymbolTable symbols, ExternalDataTypeProvider dataTypes) load facts from filesvoidLoaderProvider.loadByStream(InputStream stream, InputStream companionstream, String format, SymbolTable symbols, ExternalDataTypeProvider dataTypes) load facts by stream. format is either the file format like json,nq etc.voidExtensionalDB.loadFactsFiles(List<String> files, boolean deleteold, SymbolTable symbolTable, ExternalDataTypeProvider datatypes, BuiltinProvider builtins) reads facts files in ordinary predicate formvoidExtensionalDB.loadFiles(List<String> files, SymbolTable symbols, ExternalDataTypeProvider dataTypes) load all kind of files (besides OO-logic files)voidExtensionalDB.recreateIndices(SymbolTable symbols) recreate indices for propertiesbooleanExtensionalDB.removeTuple(String predicate, TupleBuffer tuple) remove a tuple from edb.voidExtensionalDB.reOpen()reopens a closed extensional databasevoidrestore the edb from a backup file.voidExtensionalDB.restore(List<String> predicatesToRestore, boolean restoreSymbolTable, String edbdir, String workdir, String logDir, String backupfile, ExternalDataTypeProvider datatypes, int maxTermLength) restore single predicates and/or symbol table from a backup file.voidExtensionalDB.restoreOld(String edbdir, String workdir, String logdir, String backupfile, ExternalDataTypeProvider datatypes, int maxTermLength) restore the edb from a backup file.Constructors in com.semedy.reasoner.api.edb that throw SemReasonerExceptionModifierConstructorDescriptiona no name main memory edb without transactionsExtensionalDB(String edbdir, String tempdir, String logDir, Configuration.StorageType storage, Set<String> excludedPredicates, long maxtermstoload, boolean compress, List<Literal> partition, boolean transactionLog, String[] indexedprops, Configuration config) ExtensionalDB(List<Literal> partitions, Configuration config) -
Uses of SemReasonerException in com.semedy.reasoner.api.idb
Subclasses of SemReasonerException in com.semedy.reasoner.api.idbMethods in com.semedy.reasoner.api.idb that throw SemReasonerExceptionModifier and TypeMethodDescriptionbooleanIntensionalDB.addAllRules(Collection<Rule> rules) Add a whole collection of rules.booleanAdd a query which is a rule without head.booleanAdd a rule.booleanAdd rulesvoidIntensionalDB.createAxioms(SymbolTable symbols, ExternalDataTypeProvider datatypes, Configuration config) create the relevant axiomsvoidIntensionalDB.createRuleGraph(SymbolTable symboltable) Creates a rule graph.voidIntensionalDB.exportRules(Writer out, SymbolTable symbolTable) export all rulesvoidIntensionalDB.exportRules(String filepath, boolean append, SymbolTable symbolTable) store all rules in file given by file pathvoidIntensionalDB.loadRuleFiles(List<String> files, SymbolTable symbolTable, ExternalDataTypeProvider datatypes, BuiltinProvider builtins) load rules from filevoidIntensionalDB.removeAxioms(SymbolTable symbols, ExternalDataTypeProvider datatypes, Configuration config) remove the relevant axiomsIntensionalDB.ruleToString(Rule r, SymbolTable symbols) return an OO-Logic representation of the ruleIntensionalDB.selectRules(List<Rule> rules, BuiltinProvider builtins) select all rules transitively feeding into rulesIntensionalDB.toString(SymbolTable symbols) -
Uses of SemReasonerException in com.semedy.reasoner.api.induction
Methods in com.semedy.reasoner.api.induction that throw SemReasonerExceptionModifier and TypeMethodDescriptionvoidSimilarityTrainer.trainRules(Collection<String> ruleNames, String query4Positives, String query4Negatives, int stepRate) adapt similarity built-ins in rules to cover max positives and min negatives.Constructors in com.semedy.reasoner.api.induction that throw SemReasonerException -
Uses of SemReasonerException in com.semedy.reasoner.api.logic
Methods in com.semedy.reasoner.api.logic that throw SemReasonerExceptionModifier and TypeMethodDescriptionLiteral.toString(SymbolTable symbols) Rule.toString(SymbolTable symbols) Rule.toString(SymbolTable symbols, List<Rule> aggregationRules) -
Uses of SemReasonerException in com.semedy.reasoner.api.parser
Subclasses of SemReasonerException in com.semedy.reasoner.api.parserMethods in com.semedy.reasoner.api.parser that throw SemReasonerExceptionModifier and TypeMethodDescriptionstatic voidParserUtils.loadAllFactsAndRulesInDirectory(String directoryPath, Set<Rule> rules, Set<Literal> facts, int maxTermLength) load all rules and facts in files in same (flat) directoryvoidGraphQLParser.parseQuery(InputStream input, Map<String, Object> variables) parse GraphQL query and create (several) OO-logic queriesvoidGraphQLParser.parseQuery(Reader input, Map<String, Object> variables) parse GraphQL query and create an OO-logic queryvoidGraphQLParser.parseQuery(StringReader input, Map<String, Object> variables) parse GraphQL query and create an OO-logic queryvoidGraphQLParser.parseQuery(String input, Map<String, Object> variables) parse GraphQL query and create an OO-logic queryparse rule from a stringRuleParser.parseRules(String input) parse several rules from input stringvoidRuleParser.parseRulesOrFacts(InputStream input, Collection<Rule> parsedRules, Collection<Literal> parsedFacts) parse rules and facts in input stream to the containers parsedRules and parsedFactsvoidRuleParser.parseRulesOrFacts(Reader input, Collection<Rule> parsedRules, Collection<Literal> parsedFacts) parse rules and facts from reader to the containers parsedRules and parsedFactsvoidRuleParser.parseRulesOrFacts(StringReader input, Collection<Rule> parsedRules, Collection<Literal> parsedFacts) parse rules and facts from string reader to the containers parsedRules and parsedFactsvoidRuleParser.parseRulesOrFacts(String input, Collection<Rule> parsedRules, Collection<Literal> parsedFacts) parse rules and facts from string to the containers parsedRules and parsedFacts -
Uses of SemReasonerException in com.semedy.reasoner.api.reasoning
Subclasses of SemReasonerException in com.semedy.reasoner.api.reasoningMethods in com.semedy.reasoner.api.reasoning that throw SemReasonerExceptionModifier and TypeMethodDescriptionvoidReasoner.compile(IntensionalDB idb, ExtensionalDB[] edbs, ReasoningMonitor monitor, SystemMonitor smonitor, boolean topdown, int maxNumberOfResults, boolean streamReasoning, boolean streamReasoningWithRetracts) compile rules for the reasoning processReasoner.evaluate()starts evaluation and returns iterators for the results of the evaluationvoidStarts evaluation and feed the results into receiverReasoner.evaluateSeveralQueries()Starts evaluation for several queries.voidReasoner.evaluationFinished()Is called after reasoning process is finishedvoidReasoningMonitor.postBuiltinExecution(Rule rule, Literal literal, String operatorName, String receiverName, ReasoningRelation[] relationA, long numResultTuples, ReasoningRelation result, String msg) Called after a built-in has been executedvoidReasoningMonitor.postJoin(Rule rule, Literal literal, String operatorName, String receiverName, ReasoningRelation[] relationA, ReasoningRelation[] relationB, long numResultTuples, ReasoningRelation result, String joinType, String msg) Called after a join or negation is executed.booleanReceiver.receiveRelation(ReasoningRelation relation) receive a whole relationbooleanReceiver.receiveTuple(int tuple) receive a single tuplebooleanReceiver.receiveTuple(long[] tuple) receive a single tuplebooleanReceiver.receiveTuple(TupleBuffer tuple) receive a single tuplevoidReasoner.register(InterruptFlag interruptFlag, List<EventResultReceiver> receiver, CoreReadLock edbReadLock) Register several queries for events caused by sensors or in case of
stream reasoning db caused by added facts.
Every time events from sensors arrive there might be one or more new results.
For every result receiver.receive is called
This is used for stream reasoningvoidReasoningMonitor.setIntensionalDB(IntensionalDB idb) Set the intensional db, e.g. to utilize the rule graphbooleanReasoner.test(Reader in, SymbolTable baseTable, ExternalDataTypeProvider datatypes, ExtensionalDB edb, boolean topdown, String path, BuiltinProvider builtinProvider, RewriterProvider rewriterProvider, Configuration config, Properties prp) Testing the evaluation.voidReceiver.tuplesFinished(boolean isBottomUp) finish delivering single tuplesvoidReceiver.tuplesFinished(String annotation, ReasoningRelation T1, ReasoningRelation T2) Finish delivering single tuples. -
Uses of SemReasonerException in com.semedy.reasoner.api.rewriter
Subclasses of SemReasonerException in com.semedy.reasoner.api.rewriterMethods in com.semedy.reasoner.api.rewriter that throw SemReasonerExceptionModifier and TypeMethodDescriptionRewriterProvider.applyRewriter(IntensionalDB input, ExtensionalDB[] edbs, SymbolTable symbols, ExternalDataTypeProvider datatypes, BuiltinProvider builtins, SystemMonitor statistics, Configuration config, Properties prp) Apply rewriters of rewriterList in that sequence which is given by their indices and indicated by their enumerationRewriter.rewrite(IntensionalDB idb, ExtensionalDB[] edbs, SymbolTable symbolTable, ExternalDataTypeProvider datatypes, Configuration config) applies the rewriter to a set of rules -
Uses of SemReasonerException in com.semedy.reasoner.api.symboltable
Subclasses of SemReasonerException in com.semedy.reasoner.api.symboltableMethods in com.semedy.reasoner.api.symboltable that throw SemReasonerExceptionModifier and TypeMethodDescriptionvoidSymbolTable.clear()remove all symbolslongSymbolTable.createFunctionCode(long[] t, Function f) create function codeSymbolTable.createNonGroundFunction(Function t) Compile a non-ground function into a non-ground internalized function.SymbolTable.decodeNonGroundFunction(Function t) decompiles a ground internal function into an external functionvoidSymbolTable.delete()delete all / release fileslongInternalize a value.longSymbolTable.encodeNotInternalize(Object t) Returns a code for an object but does not internalize the object.longSymbolTable.encodeWOEncoding(Object t) Internalize a value.longsearches the code for a value returns 0 if term is not registeredlongSymbolTable.getFunctionCode(long[] t) get function codelong[]SymbolTable.getFunctionEncoding(long code) Returns the codes of the arguments of a function given by codeSymbolTable.getValue(long code) Produces a value from the code of an internal term.SymbolTable.getValueFunction(long code) Produces a value from the code of an internal function.SymbolTable.getValueSymbol(long code) Produces a value from the code of an internal term.booleanMatches a non-ground structure (function or literal) with a ground structure (function or literal).booleanSymbolTable.matchArguments(Object t, long[] groundtermarguments, long[] substitutions) Match returns for each variable v in t the symbol s v has to be substituted
by to match the arguments of t with ground term arguments.booleanSymbolTable.matchArguments(Object t, TupleBuffer groundtermarguments, long[] substitutions) voidSymbolTable.recreateSymbolTableIndexes()recreates all symbol table indexes from scratch.longSymbolTable.substitute(Object t, long[] substitutions) Substitutes the variables in a compound by the codes found in substitutions,
internalizes the resulting term and returns the code of the term.SymbolTable.substitute(Object t, Object[] substitutions) Substitutes the variables in a compound by the terms (non-ground) found in substitutions,
internalizes the resulting terms and returns either the code of the term
or a non-ground term.SymbolTable.substitute(Object t, Map<Variable, Object> substitutions) long[]SymbolTable.substituteArguments(Object t, long[] substitutions) Substitutes the variables in a compound t by the codes found in substitutions,
internalizes the resulting terms and returns the arguments of t.Object[]SymbolTable.substituteArguments(Object t, Object[] substitutions) Substitutes the variables in a compound t by the terms (non-ground) in substitutions,
internalizes the resulting terms and returns the arguments of t.voidSymbolTable.transactionBegin()begin a transaction.voidSymbolTable.transactionCommit()commit last changesvoidSymbolTable.transactionRollback()abort last changesbooleanUnifies two structures (functions or literals).booleanUnifies two structures (variables, terms, functions or literals).booleanSymbolTable.unify(Object t, Object f, Map<Variable, Object> substitutions, Map<Variable, Set<Variable>> equivalentVariables) Unifies two structures (variables, terms, functions or literals). -
Uses of SemReasonerException in com.semedy.reasoner.app
Methods in com.semedy.reasoner.app that throw SemReasonerExceptionModifier and TypeMethodDescriptionbooleanAPIMethods.createJson(String jsonS) create a new json objectbooleanAPIMethods.deleteJson(String id) delete json with idbooleanCheck4Bug.errorStillHere(List<String> factfilepaths, List<String> rulefilepaths) check whether problem still existsbooleanCheck4Bulk.errorStillHere(List<String> factfilepaths, List<String> rulefilepaths) booleanCheck4DoubleLoad.errorStillHere(String factfilepath, List<String> rulefilepaths) booleanCheck4JsonBug.errorStillHere(String factfilepaths, List<String> rulefilepaths) check whether problem still existsbooleanCheck4Replay.errorStillHere(String factfilepath, List<String> rulefilepaths) booleanCheck4SymbolTable.errorStillHere(String factfilepath, List<String> rulefilepaths) QueryRunner.eval(InterruptFlag interruptflag, String flogic, String query, ReasoningMonitor monitor) find jsons with a OO-logic query
Variable ?static voidTripleGenerator.generateTriples(long startUniversities, long numberOfUniversities, String outputdir, boolean ang, boolean randomized, long maxtuples, Core core) org.json.JSONObjectget json with idvoidFoil.load()voidMultiInterpreter.load()voidload file from path if path is an url the file is stored in the archive directory and then loadedstatic voidstatic voidstatic voidstatic voidstatic voidstatic voidstatic voidstatic voidstatic voidstatic voidstatic voidstatic voidstatic voidstatic voidstatic voidstatic voidvoidDebuggingMonitor.postBuiltinExecution(Rule rule, Literal literal, String operatorName, String receiverName, ReasoningRelation[] relationA, long numResultTuples, ReasoningRelation result, String msg) voidDebuggingMonitor.postJoin(Rule rule, Literal literal, String operatorName, String receiverName, ReasoningRelation[] relationA, ReasoningRelation[] relationB, long numResultTuples, ReasoningRelation result, String joinType, String msg) static voidQueryRegister.query(InterruptFlag interruptflag, String querypath, PrintStream out) static voidQueryRunner.query(InterruptFlag interrupt, String querypath, PrintStream out) APIMethods.queryJsons(String ooquery) query for jsons
In contrast to find jsons, query jsons combines jsons from triples.voidQueryRegister.register(InterruptFlag interruptFlag, String flogic, String query, ReasoningMonitor monitor, PrintStream out) voidRepairEDB.repairIt(Configuration config) voidvoidJsonProblemMinimizer.run()Run the minimizer
and store the results in temp directory (given in CheckBug).voidProblemMinimizer.run()Run the minimizer
and store the results in temp directory (given in CheckBug).voidMultiInterpreter.shutdown()voidbooleanAPIMethods.updateJson(String jsonS) update an existing json with same identifier @idConstructors in com.semedy.reasoner.app that throw SemReasonerException -
Uses of SemReasonerException in com.semedy.reasoner.builtin.action
Methods in com.semedy.reasoner.builtin.action that throw SemReasonerExceptionModifier and TypeMethodDescriptionbooleanAssert.isTrue(long[] input) booleanConstraintException.isTrue(long[] input) booleanMoneyTransfer.isTrue(long[] input) booleanPrintOut.isTrue(long[] input) booleanPrintToFile.isTrue(long[] input) booleanRaspiGpioOut.isTrue(long[] input) booleanRetract.isTrue(long[] input) booleanSendMail.isTrue(long[] input) booleanSendMail2.isTrue(long[] input) booleanToCSV.isTrue(long[] input) booleanToJSON.isTrue(long[] input) -
Uses of SemReasonerException in com.semedy.reasoner.builtin.aggregation
Methods in com.semedy.reasoner.builtin.aggregation that throw SemReasonerExceptionModifier and TypeMethodDescriptionvoidAbstractAggregation.evaluate(BuiltinReceiver receiver) voidCollatingCompose.evaluate(BuiltinReceiver receiver) voidCompose.evaluate(BuiltinReceiver receiver) voidAbstractAggregation.input(long[] input) -
Uses of SemReasonerException in com.semedy.reasoner.builtin.connector
Methods in com.semedy.reasoner.builtin.connector that throw SemReasonerExceptionModifier and TypeMethodDescriptionvoidCountEventsInTime.input(long[] input) voidCurrency.input(long[] input) voidQuery.input(long[] input) voidReasonerQuery.input(long[] input) voidCurrency.stop()voidQuery.stop()voidReasonerQuery.stop()voidTestMultiRelational.stop()voidTestMultiRelationalCached.stop() -
Uses of SemReasonerException in com.semedy.reasoner.builtin.directfilter
Methods in com.semedy.reasoner.builtin.directfilter that throw SemReasonerExceptionModifier and TypeMethodDescriptionbooleanIsNotFunctional2.receiveRelation(ReasoningRelation relation) booleanIsNotFunctional3.receiveRelation(ReasoningRelation relation) booleanIsNotFunctional2.receiveTuple(int tuple) booleanIsNotFunctional2.receiveTuple(long[] buffer) booleanIsNotFunctional2.receiveTuple(TupleBuffer buffer) booleanIsNotFunctional3.receiveTuple(int tuple) booleanIsNotFunctional3.receiveTuple(TupleBuffer buffer) voidIsNotFunctional2.tuplesFinished(boolean isBottomUp) voidIsNotFunctional2.tuplesFinished(String annotation, ReasoningRelation T1, ReasoningRelation T2) -
Uses of SemReasonerException in com.semedy.reasoner.builtin.filter
Methods in com.semedy.reasoner.builtin.filter that throw SemReasonerExceptionModifier and TypeMethodDescriptionbooleanbooleanvoidvoidvoidbooleanBooleanExpression.isTrue(long[] input) booleanComparisonBuiltin.isTrue(long[] input) booleanComparisonBuiltin2.isTrue(long[] input) booleanComparisonBuiltinNew.isTrue(long[] input) booleanContainsSimilar.isTrue(long[] input) booleanFalse.isTrue(long[] input) booleanInstanceFilterBuiltin.isTrue(long[] input) booleanIsCalendar.isTrue(long[] input) booleanIsDouble.isTrue(long[] input) booleanIsEqualSet.isTrue(long[] input) booleanIsFloat.isTrue(long[] input) booleanIsJsonId.isTrue(long[] input) booleanIsJsonTopId.isTrue(long[] input) booleanIsNumber.isTrue(long[] input) booleanIsSet.isTrue(long[] input) booleanIsString.isTrue(long[] input) booleanIsSubset.isTrue(long[] input) booleanIsType.isTrue(long[] input) booleanJaroWinklerSimilarityBuiltin.isTrue(long[] input) booleanPrint.isTrue(long[] input) booleanRaspiGpioOut.isTrue(long[] input) booleanRegularExpression.isTrue(long[] input) booleanSeek.isTrue(long[] input) booleanSelect.isTrue(long[] input) booleanStartsWithOneOf.isTrue(long[] input) booleanSubJsonId.isTrue(long[] input) booleanTrue.isTrue(long[] input) -
Uses of SemReasonerException in com.semedy.reasoner.builtin.functional
Methods in com.semedy.reasoner.builtin.functional that throw SemReasonerExceptionModifier and TypeMethodDescriptionbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanEvaluate returns the stock price for the given symbol.booleanbooleanbooleanbooleanbooleanbooleanbooleanboolean -
Uses of SemReasonerException in com.semedy.reasoner.builtin.relational
Methods in com.semedy.reasoner.builtin.relational that throw SemReasonerExceptionModifier and TypeMethodDescriptionvoidBuiltins1.evaluate(long[] input, BitSet grounds, BuiltinReceiver receiver) voidBuiltins2.evaluate(long[] input, BitSet grounds, BuiltinReceiver receiver) voidEnumerate.evaluate(long[] input, BitSet grounds, BuiltinReceiver receiver) voidGeoSearch.evaluate(long[] input, BitSet grounds, BuiltinReceiver receiver) voidIn.evaluate(long[] input, BitSet grounds, BuiltinReceiver receiver) voidNGram.evaluate(long[] input, BitSet grounds, BuiltinReceiver receiver) voidPredicates.evaluate(long[] input, BitSet grounds, BuiltinReceiver receiver) voidRegularExpression.evaluate(long[] input, BitSet grounds, BuiltinReceiver receiver) voidSeek3.evaluate(long[] input, BitSet grounds, BuiltinReceiver receiver) voidSeek4.evaluate(long[] input, BitSet grounds, BuiltinReceiver receiver) voidSeek5.evaluate(long[] input, BitSet grounds, BuiltinReceiver receiver) voidSeekAnd.evaluate(long[] input, BitSet grounds, BuiltinReceiver receiver) voidSqrt.evaluate(long[] input, BitSet grounds, BuiltinReceiver receiver) voidTextSearch2.evaluate(long[] input, BitSet grounds, BuiltinReceiver receiver) voidTextSearch3.evaluate(long[] input, BitSet grounds, BuiltinReceiver receiver) voidTimeRaster.evaluate(long[] input, BitSet grounds, BuiltinReceiver receive) voidWindow.evaluate(long[] input, BitSet grounds, BuiltinReceiver receiver) voidvoidvoidvoidvoidvoid -
Uses of SemReasonerException in com.semedy.reasoner.builtin.sensor
Methods in com.semedy.reasoner.builtin.sensor that throw SemReasonerException -
Uses of SemReasonerException in com.semedy.reasoner.builtin.similarity
Methods in com.semedy.reasoner.builtin.similarity that throw SemReasonerException -
Uses of SemReasonerException in com.semedy.reasoner.core
Methods in com.semedy.reasoner.core that throw SemReasonerExceptionModifier and TypeMethodDescriptionQueryHandler.applyRewriter(IntensionalDB input, ExtensionalDB[] edbs, SymbolTable symbols, ExternalDataTypeProvider datatypes, Configuration config, boolean withMagicSets, Properties builtinConfig) static org.json.JSONObjectJsonUtils.arrayify(org.json.JSONObject json, org.json.JSONObject schema) create arrays according to the arrays in the schemastatic org.json.JSONObjectJsonUtils.arrayifySchema(Object value) create arrays in a Json schema for enumsstatic org.json.JSONObjectJsonUtils.createJsonObject(Pattern pattern, TermParser parser) Create a json object from a pattern with values as a result of a mutation graphqlvoidCompose.evaluate(BuiltinReceiver receiver) booleanvoidContainsSequence.evaluate(BuiltinReceiver receiver) voidContainsSequence2.evaluate(BuiltinReceiver receiver) voidPerformanceTest0.ContainsSequence.evaluate(BuiltinReceiver receiver) static org.json.JSONObjectJsonUtils.fillPattern(Pattern pattern, ResultBuffer buffer, Map<String, Set<String>> subclasses) fill a graphql pattern with the result of a queryResultBufferNotThreaded.get(int index) Get object at argument indexGet object with variable name.voidContainsSequence.input(long[] input) voidContainsSequence2.input(long[] input) voidPerformanceTest0.ContainsSequence.input(long[] input) booleanOptimizedContainsSequence.isTrue(long[] input) booleanPerformanceTest0.ContainsWord.isTrue(long[] input) voidQueryHandler.loadQueries()Load rule files for queries in query directory and
store them in mapvoidwrite the current action with the given json string into a log file.booleanTransactionManager.longTransactionBegin(Transaction transaction) start a long transaction within a begin
Returns false if a long transaction is already runningvoidTransactionManager.longTransactionEnd(Transaction transaction) finish a long transaction within a commitvoidModify edb according to log file
Path can be a single file or a directorybooleanIntermediateResultProducer.receiveRelation(ReasoningRelation relation) static voidTransactionLogHandler.replayTransactionLogs(String logdir, ExtensionalDB edb, SymbolTable symbols, ExternalDataTypeProvider datatypes) Search for corrupted predicates in logdir and
Replay corresponding transaction log into edb relations.static voidTransactionLogHandler.replayTransactionLogs(List<String> predicates, String logdir, ExtensionalDB edb, SymbolTable symbols, ExternalDataTypeProvider externalDataTypes) Replay transaction files of predicates.QueryHandler.rewrite(IntensionalDB idb, ExtensionalDB[] edbs, SymbolTable symbolTable, ExternalDataTypeProvider datatypes, Configuration config) voidJsonThreadingTest.test()voidJsonThreadingTest1.test()voidJsonThreadingTest2.test()voidJsonArrayIfyTest.test1()voidJsonRecreateTest.test1()voidJsonValidateTest.test1()voidJsonValidateTest.test10()voidJsonValidateTest.test11()voidJsonRecreateTest.test12()voidJsonValidateTest.test12()voidJsonValidateTest.test13()voidJsonValidateTest.test14()voidJsonArrayIfyTest.test2()voidJsonRecreateTest.test2()voidJsonValidateTest.test2()voidJsonArrayIfyTest.test3()voidJsonRecreateTest.test3()voidJsonArrayIfyTest.test3a()voidJsonArrayIfyTest.test4()voidJsonRecreateTest.test4()voidJsonArrayIfyTest.test5()voidJsonRecreateTest.test5()voidJsonArrayIfyTest.test6()voidJsonRecreateTest.test6()voidJsonRecreateTest.test7()voidJsonValidateTest.test7()voidJsonRecreateTest.test8()voidJsonValidateTest.test9()voidTestDDB4.testEDB7()voidDeductiveDatabaseTest.testLongTransaction()Object[]ResultBufferNotThreaded.toArray()get an array of result objectsvoidTransactionManager.transactionBegin(InterruptFlag interruptflag, Transaction transaction) start a transaction in for a queryvoidTransactionManager.transactionBegin(Transaction transaction) start a general transactionvoidTransactionManager.transactionEnd(Transaction transaction) finish a transactionvoidTransactionManager.writeTransactionBegin(Transaction transaction) start a writing transaction within a beginvoidTransactionManager.writeTransactionEnd(Transaction transaction) finish a writing transaction within a commit -
Uses of SemReasonerException in com.semedy.reasoner.customer.deuba
Methods in com.semedy.reasoner.customer.deuba that throw SemReasonerException -
Uses of SemReasonerException in com.semedy.reasoner.edb
Methods in com.semedy.reasoner.edb that throw SemReasonerException -
Uses of SemReasonerException in com.semedy.reasoner.edb.loader
Methods in com.semedy.reasoner.edb.loader that throw SemReasonerExceptionModifier and TypeMethodDescriptionvoidvoidvoidJsonLoader.readJsonFromStream(Reader ins) voidJsonLoader3.readJsonFromStream(Reader ins) -
Uses of SemReasonerException in com.semedy.reasoner.edb.persistentstore
Subclasses of SemReasonerException in com.semedy.reasoner.edb.persistentstoreMethods in com.semedy.reasoner.edb.persistentstore that throw SemReasonerExceptionModifier and TypeMethodDescriptionvoidexport and import jsons to remove deleted jsons from filevoidBplusIndexJsons.importJsons(String path) import jsons from filevoidBplusIndexJsons.readJsonFromStream(InputStream in) read jsons from stream -
Uses of SemReasonerException in com.semedy.reasoner.edb.ramstore
Subclasses of SemReasonerException in com.semedy.reasoner.edb.ramstore -
Uses of SemReasonerException in com.semedy.reasoner.edb.zdb
Methods in com.semedy.reasoner.edb.zdb that throw SemReasonerExceptionModifier and TypeMethodDescriptionbooleanSchemas.build()build schema and hierarchy information in edbvoidstatic voidExternalSort.merge(List<File> files, ExternalSortConsumer consumer, boolean deleteinputfiles, boolean compressed) static voidExternalSortRawTuples.merge(List<File> files, ExternalSortConsumer consumer, boolean deleteinputfiles, boolean compressed) static voidExternalSortTuples.merge(List<File> files, ExternalSortConsumer consumer, boolean deleteinputfiles, boolean compressed) static voidExternalSortRawTuples.mergeBytesZipped(List<File> files, ExternalSortConsumer consumer, boolean deleteinputfiles, boolean compressed) static voidExternalSortRawTuples.mergeZipped(List<File> files, ExternalSortConsumer consumer, boolean deleteinputfiles, boolean compressed) voidLoader.receiveFile(String filename) voidRelationLoader.receiveFile(String filename) Constructors in com.semedy.reasoner.edb.zdb that throw SemReasonerException -
Uses of SemReasonerException in com.semedy.reasoner.exercises
Methods in com.semedy.reasoner.exercises that throw SemReasonerExceptionModifier and TypeMethodDescriptionbooleanvoidMean.evaluate(BuiltinReceiver receiver) voidSqrt.evaluate(long[] input, BitSet grounds, BuiltinReceiver receiver) voidMean.input(long[] input) booleanIsString.isTrue(long[] input) static voidstatic voidRemoveDoubleLiterals.rewrite(IntensionalDB idb, ExtensionalDB[] edbs, SymbolTable symbolTable, ExternalDataTypeProvider datatypes, Configuration config) voidFilterA.stop()voidFilterB.stop() -
Uses of SemReasonerException in com.semedy.reasoner.idb
Methods in com.semedy.reasoner.idb that throw SemReasonerException -
Uses of SemReasonerException in com.semedy.reasoner.induction
Methods in com.semedy.reasoner.induction that throw SemReasonerExceptionModifier and TypeMethodDescriptionvoidRuleInduction.foil()voidInductionTest.train(String positive, String negative, String headPredicate, List<String> bodyPredicates) Constructors in com.semedy.reasoner.induction that throw SemReasonerException -
Uses of SemReasonerException in com.semedy.reasoner.parser.graphql
Methods in com.semedy.reasoner.parser.graphql that throw SemReasonerExceptionModifier and TypeMethodDescriptionvoidInternalGraphQLParser.parseQuery(InputStream input, Map<String, Object> variables) parse rules and facts in input stream to the containers parsedRules and parsedFactsvoidInternalGraphQLParser.parseQuery(Reader input, Map<String, Object> variables) parse rules and facts from reader to the containers parsedRules and parsedFactsvoidInternalGraphQLParser.parseQuery(StringReader input, Map<String, Object> variables) parse rules and facts from string reader to the containers parsedRules and parsedFactsvoidInternalGraphQLParser.parseQuery(String input, Map<String, Object> variables) parse rules and facts from string to the containers parsedRules and parsedFacts -
Uses of SemReasonerException in com.semedy.reasoner.parser.oologic
Methods in com.semedy.reasoner.parser.oologic that throw SemReasonerExceptionModifier and TypeMethodDescriptionstatic voidParserUtils.loadAllClasses(String directoryPath, Set<String> classes) Return all predicates and classes in all files in same (flat) directorystatic SymbolTableParserUtils.loadAllFactsAndRulesInDirectory(String directoryPath, Set<Rule> rules, Set<Literal> facts, int maxTermLength) load all rules and facts in files in same (flat) directorystatic voidParserUtils.loadAllPredicateSymbols(String directoryPath, Set<String> predicates) Return all predicates in all files in same (flat) directoryparse rule from a stringInternalOOLogicParser.parseRules(String input) parse several rules from input stringvoidInternalOOLogicParser.parseRulesOrFacts(InputStream input, Collection<Rule> parsedRules, Collection<Literal> parsedFacts) parse rules and facts in input stream to the containers parsedRules and parsedFactsvoidInternalOOLogicParser.parseRulesOrFacts(Reader input, Collection<Rule> parsedRules, Collection<Literal> parsedFacts) parse rules and facts from reader to the containers parsedRules and parsedFactsvoidInternalOOLogicParser.parseRulesOrFacts(StringReader input, Collection<Rule> parsedRules, Collection<Literal> parsedFacts) parse rules and facts from string reader to the containers parsedRules and parsedFactsvoidInternalOOLogicParser.parseRulesOrFacts(String input, Collection<Rule> parsedRules, Collection<Literal> parsedFacts) parse rules and facts from string to the containers parsedRules and parsedFacts -
Uses of SemReasonerException in com.semedy.reasoner.reasoning
Methods in com.semedy.reasoner.reasoning that throw SemReasonerExceptionModifier and TypeMethodDescriptionvoidReasonerNotThreaded.compile(IntensionalDB idb, ExtensionalDB[] edbs, ReasoningMonitor monitor, SystemMonitor smonitor, boolean topdown, int[] partsVector, boolean cepReasoningWithRetracts, boolean cepReasoning) voidReasonerNotThreaded.compile(IntensionalDB idb, ExtensionalDB[] edbs, ReasoningMonitor monitor, SystemMonitor smonitor, boolean topdown, int maxNumberOfResults, boolean streamReasoning, boolean cepReasoningWithRetracts) Compile rules to a data flowvoidReasonerThreadedFactsPartitioning.compile(IntensionalDB idb, ExtensionalDB[] edbs, ReasoningMonitor monitor, SystemMonitor smonitor, boolean topdown, int maxNumberOfResults, boolean cepReasoningWithRetracts, boolean cepReasoning) voidReasonerThreadedRulesPartitioning.compile(IntensionalDB idb, ExtensionalDB[] edbs, ReasoningMonitor monitor, SystemMonitor smonitor, boolean topdown, int maxNumberOfResults, boolean cepReasoningWithRetracts, boolean cepReasoning) voidvoidAbstractTestTemplate.eval(String flogic, String fqueries, List<Vector<String>> results, boolean applyRewriters) ReasonerNotThreaded.evaluate()Start evaluation and return an iterator for the resultsvoidReasonerThreadedFactsPartitioning.evaluate()voidReasonerThreadedRulesPartitioning.evaluate()ReasonerThreadedRulesPartitioning.evaluate(ReasoningMonitor monitor) voidReasonerNotThreaded.evaluateSeveralQueries()voidReasonerNotThreaded.evaluationFinished()evaluation is finishedvoidAbstractTestTemplate.evalWithoutResults(String flogic, String fquery) voidAbstractTestTemplate1.evalWithoutResults(Core core, String flogic, String fquery) voidbooleanBuiltinsTest.SuperSimpleBuiltin.isTrue(long[] input) booleanExceptionBuiltin.isTrue(long[] input) voidIncrementalFactsBuiltin.receiveEvent(long[] tuple) voidIncrementalFactsBuiltin.receiveEvent(TupleBuffer tuple) voidIncrementalFactsBuiltin.receiveRelation(BaseRelation relation) voidReasonerNotThreaded.register(InterruptFlag interruptFlag, EventResultReceiver receiver, CoreReadLock edbReadLock) voidReasonerNotThreaded.register(InterruptFlag interruptFlag, List<EventResultReceiver> receiver, CoreReadLock edbReadLock) booleanReasonerNotThreaded.test(Reader in, SymbolTable baseTable, ExternalDataTypeProvider datatypes, ExtensionalDB edb, boolean topdown, String path, BuiltinProvider builtinProvider, RewriterProvider rewriterProvider, Configuration config, Properties prp) testing the evaluation.voidJoinCacheTest.test1()voidJoinCacheTest.test2()voidInternalizeTest.test3()voidLogic.test331()voidLogic.test331a()booleanAbstractTestTemplate.testFile(Reader is, String path, boolean topdown, Configuration.StorageType storage, boolean symboltableondisc, boolean directencoded) voidMassTest.testMass1()voidMassTest.testMass2()voidMassTest.testSwap() -
Uses of SemReasonerException in com.semedy.reasoner.reasoning.monitor
Methods in com.semedy.reasoner.reasoning.monitor that throw SemReasonerExceptionModifier and TypeMethodDescriptionvoidDefaultReasoningMonitor.setIntensionalDB(IntensionalDB idb) -
Uses of SemReasonerException in com.semedy.reasoner.reasoning.processes
Methods in com.semedy.reasoner.reasoning.processes that throw SemReasonerExceptionModifier and TypeMethodDescriptionRuleCompiler.compileRules()compile all rules and create a process netRuleCompiler.compileRules(int[] partsVector) compile all rules and create a process graphlongReasoningSymbolTableNotInternalize.createFunctionCode(long[] t, Function f) voidDeferred.deferredEvaluate()voidExecuteAggregation.deferredEvaluate()voidNot.deferredEvaluate()voidRuleEvaluator.deferredEvaluate()longlongReasoningSymbolTableNotInternalize.encodeNotInternalize(Object t) longReasoningSymbolTableNotInternalize.encodeWOEncoding(Object t) voidAnd.evaluate()voidBufferedStore.evaluate()voidEmptyStore.evaluate()voidEvaluable.evaluate()voidExecuteAggregation.evaluate()voidExecuteConnectorBuiltin.evaluate()voidExecuteFilterBuiltin.evaluate()voidExecuteFunctionalBuiltin.evaluate()voidExecuteRelationalBuiltin.evaluate()voidNot.evaluate()voidProcess.evaluate()evaluate a process during reasoning.voidProcessExecutor.evaluate()voidProcessExecutor.evaluate(InterruptFlag interruptFlag, SimpleSemaphore semaphoreForSensors, CoreReadLock edbReadlock, Set<String> predicates) voidProcessImp.evaluate()voidRuleEvaluator.evaluate()voidStore.evaluate()evaluate the storevoidSynchronizedBufferedStore.evaluate()voidUnbufferedStore.evaluate()voidProcessExecutor.evaluateConnectors()voidRuleEvaluator.evaluateInternal()voidRuleEvaluator.evaluateThreaded()booleanExecuteConnectorBuiltin.evaluateWoBuiltin()voidBufferedStore.evaluationFinished(long querykey) voidEmptyStore.evaluationFinished(long querykey) voidExecuteRelationalBuiltin.evaluationFinished(long querykey) voidProcess.evaluationFinished(long querykey) the whole evaluation is finishedvoidProcessExecutor.evaluationFinished()voidProcessImp.evaluationFinished()voidProcessImp.evaluationFinished(long querykey) voidResultReceiver.evaluationFinished()voidStore.evaluationFinished(long querykey) Evaluation for query with querykey is finishedvoidUnbufferedStore.evaluationFinished(long querykey) Store.getAllTuplesInOne()get all received tupleslonglongReasoningSymbolTableNotInternalize.getFunctionCode(long[] t) long[]ReasoningSymbolTableNotInternalize.getFunctionEncoding(long code) BinaryPattern.getProcess(List<Literal> remainingLiterals) abstract ProcessBodyPattern.getProcess(List<Literal> remainingLiterals) ReasoningSymbolTableNotInternalize.getValue(long code) ReasoningSymbolTableNotInternalize.getValueFunction(long code) ReasoningSymbolTableNotInternalize.getValueSymbol(long code) ReasoningRelation.join(InterruptFlag interrupt, int[] compare1, ReasoningRelation R, int[] compare2, int[] source1, int[] dest1, int[] source2, int[] dest2, long[] externalFilter1, long[] externalFilter2, int destarity, Receiver receiver, com.semedy.reasoner.reasoning.processes.EvaluationThread evalThread, boolean streamReasoning, com.semedy.reasoner.reasoning.processes.SystemMonitor.JoinType joinType) voidEmptyStore.operationFinished()voidProcess.operationFinished()this process is finishedvoidProcessImp.operationFinished()voidSystemReasoningMonitor.postBuiltinExecution(Rule rule, Literal literal, String operatorName, String receiverName, ReasoningRelation[] relationA, long numResultTuples, ReasoningRelation result, String msg) voidSystemReasoningMonitor.postJoin(Rule rule, Literal literal, String operatorName, String receiverName, ReasoningRelation[] relationA, ReasoningRelation[] relationB, long numResultTuples, ReasoningRelation result, String joinType, String msg) RuleCompiler.prepareCompilation()preparation steps for compilationvoidExecuteFilterBuiltin.push()voidExecuteFunctionalBuiltin.push()voidExecuteRelationalBuiltin.push()booleanBufferedStore.readAccessEnd(ProcessImp source, Set<Integer> tickets, boolean lock, boolean notDissolve) booleanEmptyStore.readAccessEnd(ProcessImp source, Set<Integer> tickets, boolean lock, boolean pushed) booleanStore.readAccessEnd(ProcessImp source, Set<Integer> tickets, boolean lock, boolean pushed) Reading of a store ends.booleanSynchronizedBufferedStore.readAccessEnd(ProcessImp source, Set<Integer> tickets, boolean unlockit, boolean pushed) booleanUnbufferedStore.readAccessEnd(ProcessImp source, Set<Integer> tickets, boolean lock, boolean pushed) booleanBufferedStore.receiveRelation(ReasoningRelation R) booleanEmptyStore.receiveRelation(ReasoningRelation R) booleanEventReceiver.receiveRelation(ReasoningRelation relation) booleanExecuteDirectFilterBuiltin.receiveRelation(ReasoningRelation relation) booleanExecuteFilterBuiltin.receiveRelation(ReasoningRelation relation) booleanExecuteFunctionalBuiltin.receiveRelation(ReasoningRelation relation) booleanExecuteRelationalBuiltin.receiveRelation(ReasoningRelation relation) booleanMatch.receiveRelation(ReasoningRelation relation) booleanProcessImp.receiveRelation(ReasoningRelation tuples) booleanResultReceiver.receiveRelation(ReasoningRelation R) booleanScatter.receiveRelation(ReasoningRelation relation) booleanSetConstants.receiveRelation(ReasoningRelation relation) booleanStore.receiveRelation(ReasoningRelation R) receive a whole relation with tuplesbooleanSubstituteFunction.receiveRelation(ReasoningRelation relation) booleanSynchronizedBufferedStore.receiveRelation(ReasoningRelation R) booleanTestEqual.receiveRelation(ReasoningRelation relation) booleanTopDown.receiveRelation(ReasoningRelation tuples) booleanTopDownTrigger.receiveRelation(ReasoningRelation tuples) booleanTopDownUnbufferedStore.receiveRelation(ReasoningRelation R) booleanUnbufferedStore.receiveRelation(ReasoningRelation R) booleanVariableToVariable.receiveRelation(ReasoningRelation relation) booleanSetConstants.receiveRelationNoProject(ReasoningRelation relation) booleanSetConstants.receiveRelationProject(ReasoningRelation relation) booleanBufferedStore.receiveTuple(int tuple) booleanBufferedStore.receiveTuple(long[] tuple) booleanBufferedStore.receiveTuple(TupleBuffer tuple) booleanEmptyStore.receiveTuple(int tuple) booleanEmptyStore.receiveTuple(long[] tuple) booleanEmptyStore.receiveTuple(TupleBuffer tuple) booleanEncoder.receiveTuple(int tuple) booleanEncoder.receiveTuple(long[] tuple) booleanEncoder.receiveTuple(TupleBuffer tuple) booleanEnd.receiveTuple(int tuple) booleanEnd.receiveTuple(long[] tuple) booleanEnd.receiveTuple(TupleBuffer tuple) booleanEventReceiver.receiveTuple(int tuple) booleanEventReceiver.receiveTuple(long[] tuple) booleanEventReceiver.receiveTuple(TupleBuffer tuple) booleanExecuteDirectFilterBuiltin.receiveTuple(int tuple) booleanExecuteDirectFilterBuiltin.receiveTuple(long[] tuple) booleanExecuteFilterBuiltin.receiveTuple(int tuple) booleanExecuteFilterBuiltin.receiveTuple(long[] tuple) booleanExecuteFunctionalBuiltin.receiveTuple(int tuple) booleanExecuteFunctionalBuiltin.receiveTuple(long[] tuple) booleanExecuteRelationalBuiltin.receiveTuple(int tuple) booleanExecuteRelationalBuiltin.receiveTuple(long[] tuple) booleanMatch.receiveTuple(int tuple) booleanMatch.receiveTuple(long[] tuple) booleanProcessImp.receiveTuple(int tuple) booleanProcessImp.receiveTuple(long[] tuple) booleanProcessImp.receiveTuple(TupleBuffer tuple) final booleanResultReceiver.receiveTuple(int tuple) booleanResultReceiver.receiveTuple(long[] tuple) final booleanResultReceiver.receiveTuple(TupleBuffer tuple) booleanScatter.receiveTuple(int tuple) booleanScatter.receiveTuple(long[] tuple) booleanScatter.receiveTuple(TupleBuffer tuple) booleanSetConstants.receiveTuple(int tuple) booleanSetConstants.receiveTuple(long[] tuple) booleanSetConstants.receiveTuple(TupleBuffer tuple) booleanStore.receiveTuple(int tuple) receive a single tuplebooleanStore.receiveTuple(long[] tuple) receive a single tuplebooleanSubstituteFunction.receiveTuple(int tuple) booleanSubstituteFunction.receiveTuple(long[] tuple) booleanTestEqual.receiveTuple(int tuple) booleanTestEqual.receiveTuple(long[] tuple) booleanTopDownUnbufferedStore.receiveTuple(int tuple) booleanTopDownUnbufferedStore.receiveTuple(long[] tuple) booleanUnbufferedStore.receiveTuple(int tuple) booleanUnbufferedStore.receiveTuple(long[] tuple) booleanVariableToVariable.receiveTuple(int tuple) booleanVariableToVariable.receiveTuple(long[] tuple) voidProcessExecutor.reset()voidExecuteDirectFilterBuiltin.DirectFilterBuiltinReceiver.send(long[] buffer) voidExecuteDirectFilterBuiltin.DirectFilterBuiltinReceiver.send(TupleBuffer buffer) voidSystemReasoningMonitor.setIntensionalDB(IntensionalDB idb) voidBufferedStore.triggerNeighbours(int ticket) voidEmptyStore.triggerNeighbours(int ticket) voidStore.triggerNeighbours(int ticket) trigger neighbours for evaluationvoidTopDownBufferedStore.triggerNeighbours(int ticket) voidTopDownUnbufferedStore.triggerNeighbours(int ticket) voidUnbufferedStore.triggerNeighbours(int ticket) voidBufferedStore.tuplesFinished(boolean isBottomUp) voidBufferedStore.tuplesFinished(String annotation, ReasoningRelation R1, ReasoningRelation R2) voidEmptyStore.tuplesFinished(boolean isBottomUp) voidEmptyStore.tuplesFinished(String annotation, ReasoningRelation R1, ReasoningRelation R2) voidEncoder.tuplesFinished(boolean isBottomUp) voidEncoder.tuplesFinished(String annotation, ReasoningRelation T1, ReasoningRelation T2) voidEventReceiver.tuplesFinished(boolean isBottomUp) voidEventReceiver.tuplesFinished(String annotation, ReasoningRelation T1, ReasoningRelation T2) voidExecuteAggregation.tuplesFinished(String annotation, ReasoningRelation T1, ReasoningRelation T2) voidExecuteConnectorBuiltin.tuplesFinished(String annotation, ReasoningRelation T1, ReasoningRelation T2) voidExecuteDirectFilterBuiltin.tuplesFinished(String annotation, ReasoningRelation T1, ReasoningRelation T2) voidExecuteFilterBuiltin.tuplesFinished(String annotation, ReasoningRelation T1, ReasoningRelation T2) voidExecuteFunctionalBuiltin.tuplesFinished(String annotation, ReasoningRelation T1, ReasoningRelation T2) voidExecuteRelationalBuiltin.tuplesFinished(String annotation, ReasoningRelation T1, ReasoningRelation T2) voidProcessImp.tuplesFinished(boolean isBottomUp) voidProcessImp.tuplesFinished(String annotation, ReasoningRelation T1, ReasoningRelation T2) voidResultReceiver.tuplesFinished(boolean isBottomUp) voidResultReceiver.tuplesFinished(String annotation, ReasoningRelation R1, ReasoningRelation R2) voidScatter.tuplesFinished(boolean isBottomUp) voidScatter.tuplesFinished(String annotation, ReasoningRelation T1, ReasoningRelation T2) voidSetConstants.tuplesFinished(String annotation, ReasoningRelation T1, ReasoningRelation T2) voidStore.tuplesFinished(boolean isBottomUp) finish of delivery of single tuplesvoidStore.tuplesFinished(String annotation, ReasoningRelation R1, ReasoningRelation R2) finish of delivery of single tuplesvoidSubstituteFunction.tuplesFinished(String annotation, ReasoningRelation T1, ReasoningRelation T2) voidSynchronizedBufferedStore.tuplesFinished(boolean isBottomUp) voidSynchronizedBufferedStore.tuplesFinished(String annotation, ReasoningRelation R1, ReasoningRelation R2) voidUnbufferedStore.tuplesFinished(boolean isBottomUp) voidUnbufferedStore.tuplesFinished(boolean isBottomUp) voidUnbufferedStore.tuplesFinished(String annotation, ReasoningRelation R1, ReasoningRelation R2) -
Uses of SemReasonerException in com.semedy.reasoner.rewriter
Methods in com.semedy.reasoner.rewriter that throw SemReasonerExceptionModifier and TypeMethodDescriptionAxiomInjector.createAxioms(IntensionalDB idb, SymbolTable symbolTable, ExternalDataTypeProvider datatypes, Configuration config) AxiomInjector.createAxioms(Object module, SymbolTable symbols, ExternalDataTypeProvider datatypes, int i) static voidAxiomInjector.createStandardAxioms(SymbolTable symbolTable, ExternalDataTypeProvider datatypes, BuiltinProvider builtins) AxiomInjector.detectModules(Rule rule, SymbolTable symbols) booleanMagicSetRewriter.goDown(Literal l, BitSet boundVariables, String label, IntensionalDB oldIdb, IntensionalDB newIdb, ExtensionalDB[] edbs, SymbolTable symbols) booleanTopDownOrderingRewriter.goDown(Literal l, BitSet boundVariables, String label, IntensionalDB oldIdb, IntensionalDB newIdb, ExtensionalDB[] edbs, SymbolTable symbols) AxiomInjector.rewrite(IntensionalDB idb, ExtensionalDB[] edbs, SymbolTable symbolTable, ExternalDataTypeProvider datatypes, Configuration config) EliminateRedundantBodiesRewriter.rewrite(IntensionalDB idb, ExtensionalDB[] edbs, SymbolTable symbolTable, ExternalDataTypeProvider datatypes, Configuration config) FillNullRewriter.rewrite(IntensionalDB idb, ExtensionalDB[] edbs, SymbolTable symbols, ExternalDataTypeProvider datatypes, Configuration config) FilterRewriter.rewrite(IntensionalDB idb, ExtensionalDB[] edbs, SymbolTable symbolTable, ExternalDataTypeProvider datatypes, Configuration config) FolderRewriter.rewrite(IntensionalDB idb, ExtensionalDB[] edbs, SymbolTable symbolTable, ExternalDataTypeProvider datatypes, Configuration config) IsaRewriter.rewrite(IntensionalDB idb, ExtensionalDB[] edbs, SymbolTable symbolTable, ExternalDataTypeProvider datatypes, Configuration config) ModuleRewriter.rewrite(IntensionalDB idb, ExtensionalDB[] edbs, SymbolTable symbolTable, ExternalDataTypeProvider datatypes, Configuration config) ModuleRewriter.rewrite(IntensionalDB idb, SymbolTable symbolTable, String module) Fill rules into module.PathRewriter.rewrite(IntensionalDB idb, ExtensionalDB[] edbs, SymbolTable symbols, ExternalDataTypeProvider datatypes, Configuration config) PropagateConstantsRewriter.rewrite(IntensionalDB input, ExtensionalDB[] edbs, SymbolTable symbolTable, ExternalDataTypeProvider datatypes, Configuration config) QueryRuleRewriter.rewrite(IntensionalDB idb, ExtensionalDB[] edbs, SymbolTable symbols, ExternalDataTypeProvider datatypes, Configuration config) RewriterSkeleton.rewrite(IntensionalDB idb, ExtensionalDB[] edbs, SymbolTable symbolTable, ExternalDataTypeProvider datatypes, Configuration config) RuleReordering.rewrite(IntensionalDB idb, ExtensionalDB[] edbs) SeparateEDBfromIDB.separate(IntensionalDB idb, ExtensionalDB[] edbs, boolean cep) -
Uses of SemReasonerException in com.semedy.reasoner.rewriter.sips
Methods in com.semedy.reasoner.rewriter.sips that throw SemReasonerExceptionModifier and TypeMethodDescriptionbooleanTopDownSIPS.isEvaluable(Rule R, int ix, BitSet groundvars, IntensionalDB IDB, SymbolTable symbols) Is rule body beginning at index with given groundvars evaluableSIPS.orderBodies(Rule rule, BitSet groundVars, long[] groundValues, IntensionalDB idb, ExtensionalDB[] edbs, SymbolTable symbols) Arrange the bodies of a rule.TopDownSIPS.orderBodies(Rule rule, BitSet groundVars, long[] groundValues, IntensionalDB IDB, ExtensionalDB[] edbs, SymbolTable symbols) -
Uses of SemReasonerException in com.semedy.reasoner.symboltable
Methods in com.semedy.reasoner.symboltable that throw SemReasonerExceptionModifier and TypeMethodDescriptionvoidMultiSymbolTable.clear()voidReasoningSymbolTableRAM.clear()abstract longAbstractSymbolTable.createFunctionCode(long[] t, Function f) create function codelongMultiSymbolTable.createFunctionCode(long[] t, Function f) longReasoningSymbolTableRAM.createFunctionCode(long[] t, Function f) AbstractSymbolTable.createNonGroundFunction(Function f) Compile a non-ground user term into a non-ground internal term.ReasoningSymbolTable.createNonGroundFunction(Function t) Compile a non-ground user term into a non-ground internal term.AbstractSymbolTable.decodeNonGroundFunction(Function t) voidMultiSymbolTable.delete()voidReasoningSymbolTableRAM.delete()longInternalize a ground term.abstract longAbstractSymbolTable.encodeNotInternalize(Object t) longMultiSymbolTable.encodeNotInternalize(Object t) longReasoningSymbolTableRAM.encodeNotInternalize(Object t) longSymbolTableBplus.encodeNotInternalize(Object t) longSymbolTableRAM.encodeNotInternalize(Object t) longMultiSymbolTable.encodeWOEncoding(Object t) longReasoningSymbolTableRAM.encodeWOEncoding(Object t) longSymbolTableBplus.encodeWOEncoding(Object t) longSymbolTableRAM.encodeWOEncoding(Object t) longsearch for code of a termabstract longAbstractSymbolTable.getFunctionCode(long[] t) get function codelongMultiSymbolTable.getFunctionCode(long[] t) longReasoningSymbolTableRAM.getFunctionCode(long[] t) abstract long[]AbstractSymbolTable.getFunctionEncoding(long code) get the encoding of a function code, if it is therelong[]MultiSymbolTable.getFunctionEncoding(long code) long[]ReasoningSymbolTableRAM.getFunctionEncoding(long code) AbstractSymbolTable.getValue(long code) ReasoningSymbolTableRAM.getValue(long code, boolean b) abstract FunctionAbstractSymbolTable.getValueFunction(long code) get function for symbol codeMultiSymbolTable.getValueFunction(long code) ReasoningSymbolTableRAM.getValueFunction(long code) ReasoningSymbolTableRAM.getValueFunction(long code, boolean decodeSets) Produce a value from the code.SymbolTableBplus.getValueFunction(long code) final FunctionSymbolTableRAM.getValueFunction(long code) Produce a value from the code of an internal constant.abstract ObjectAbstractSymbolTable.getValueSymbol(long code) get object for symbol codeMultiSymbolTable.getValueSymbol(long code) ReasoningSymbolTableRAM.getValueSymbol(long code) ReasoningSymbolTableRAM.getValueSymbol(long code, boolean decodeSets) Produce a value from the code.SymbolTableBplus.getValueSymbol(long code) booleanIsList.isTrue(long[] input) booleanMatch returns for each variable v in t the symbol s v has to be substituted by.booleanMatch returns for each variable v in t the symbol s v has to be substituted by.booleanAbstractSymbolTable.matchArguments(Object t, long[] groundtermarguments, long[] substitutions) Match returns for each variable v in t the symbol s v has to be substituted by to match the arguments of t with groundtermarguments The result provides for variable position p the code of sbooleanAbstractSymbolTable.matchArguments(Object t, TupleBuffer groundtermarguments, long[] substitutions) booleanReasoningSymbolTable.matchArguments(Object t, long[] groundtermarguments, long[] substitutions) Match returns for each variable v in t the symbol s v has to be substituted by to match the arguments of t
with groundtermarguments.voidAbstractSymbolTable.recreateSymbolTableIndexes()voidSymbolTableBplus.restore(String edbdir, String workdir, ExternalDataTypeProvider datatypes, boolean compress, int maxTermLength) AbstractSymbolTable.semiSubstitute(Object t, long[] substitutions) substitutes the variables in a term by the codes found in substitutions.longAbstractSymbolTable.substitute(Object t, long[] substitutions) substitutes the variables in an internal term by the codes found in substitutions, internalizes the resulting term and returns the code of the term Attention: do not use this method in several threads in parallel, it is NOT threadsafe!AbstractSymbolTable.substitute(Object t, Object[] substitutions) substitutes the variables in a compound by the terms (non-ground) found in substitutions, internalizes the resulting term and returns the code of the term Attention: do not use this method in several threads in parallel, it is NOT threadsafe!AbstractSymbolTable.substitute(Object t, Map<Variable, Object> subs) longReasoningSymbolTable.substitute(Object t, long[] substitutions) substitutes the variables in an internal term by the codes found in substitutions, internalizes the resulting term and returns the code of the term Attention: do not use this method with same object t in several threads in parallel, it is NOT threadsafe!long[]AbstractSymbolTable.substituteArguments(Object t, long[] substitutions) Substitutes the variables in an internal term by the codes found in substitutions,
internalizes the resulting term and returns the code of the term.Object[]AbstractSymbolTable.substituteArguments(Object t, Object[] substitutions) substitutes the variables in an internal term by the terms (non-ground) found in substitutions, internalizes the resulting term and returns the code of the term Attention: do not use this method in several threads in parallel, it is NOT threadsafe!long[]ReasoningSymbolTable.substituteArguments(Object t, long[] substitutions) substitutes the variables in a compound t by the codes found in substitutions, internalizes the resulting terms and returns the arguments of t.AbstractSymbolTable.substituteFunction(Function f, Map<Variable, Object> subs) voidTestSymboltableDeuba.testCountry()voidMultiSymbolTable.transactionBegin()voidReasoningSymbolTableRAM.transactionBegin()voidMultiSymbolTable.transactionCommit()voidReasoningSymbolTableRAM.transactionCommit()voidSymbolTableBplus.transactionCommit()voidMultiSymbolTable.transactionRollback()voidReasoningSymbolTableRAM.transactionRollback()booleanbooleanUnifiable returns whether two structures are unifiable This method is cheaper than unify as it delivers no result substitutionsbooleanbooleanAbstractSymbolTable.unify(Object t, Object f, Map<Variable, Object> substitutions, Map<Variable, Set<Variable>> equivalences) -
Uses of SemReasonerException in com.semedy.reasoner.symboltable.encoder
Methods in com.semedy.reasoner.symboltable.encoder that throw SemReasonerException -
Uses of SemReasonerException in com.semedy.reasoner.symboltable.index
Methods in com.semedy.reasoner.symboltable.index that throw SemReasonerExceptionModifier and TypeMethodDescriptionvoidGeoIndex.recreateIndex(SymbolTable symbols, ExtensionalDB edb) recreate whole geo indexvoidTextIndex.recreateIndex(SymbolTable symbols, ExtensionalDB edb) recreate whole text index -
Uses of SemReasonerException in com.semedy.reasoner.utils
Methods in com.semedy.reasoner.utils that throw SemReasonerExceptionModifier and TypeMethodDescriptionstatic StringOOlogicShape.toString(Literal L, boolean magic, SymbolTable symbols, BuiltinProvider builtins) return OO-logic syntax for literal Lstatic StringOOlogicShape.toString(Literal L, SymbolTable symbols, BuiltinProvider builtins) return OO-logic syntax for literal Lstatic StringOOlogicShape.toString(Rule r, int markedIndex, SymbolTable symbols, BuiltinProvider builtins) return OO logic syntax for rule r, rule body 'markedIndex' is markedstatic StringOOlogicShape.toString(Rule r, SymbolTable symbols, BuiltinProvider builtins) return OO logic syntax for rule rstatic StringOOlogicShape.toString(Object term, SymbolTable symbols)