Uses of Interface
com.orientechnologies.orient.core.command.OCommandContext
Packages that use OCommandContext
Package
Description
-
Uses of OCommandContext in com.orientechnologies.common.parser
Constructors in com.orientechnologies.common.parser with parameters of type OCommandContext -
Uses of OCommandContext in com.orientechnologies.lucene.collections
Methods in com.orientechnologies.lucene.collections that return OCommandContextMethods in com.orientechnologies.lucene.collections with parameters of type OCommandContextModifier and TypeMethodDescriptionvoidOLuceneResultSet.sendLookupTime(OCommandContext commandContext, long start) OLuceneCompositeKey.setContext(OCommandContext context) -
Uses of OCommandContext in com.orientechnologies.lucene.engine
Methods in com.orientechnologies.lucene.engine with parameters of type OCommandContextModifier and TypeMethodDescriptionstatic voidOLuceneIndexEngineUtils.sendLookupTime(String indexName, OCommandContext context, org.apache.lucene.search.TopDocs docs, Integer limit, long startFetching) static voidOLuceneIndexEngineUtils.sendTotalHits(String indexName, OCommandContext context, long totalHits) -
Uses of OCommandContext in com.orientechnologies.lucene.functions
Methods in com.orientechnologies.lucene.functions with parameters of type OCommandContextModifier and TypeMethodDescriptionbooleanOLuceneSearchFunctionTemplate.allowsIndexedExecution(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) booleanOLuceneSearchMoreLikeThisFunction.allowsIndexedExecution(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) booleanOLuceneSearchFunctionTemplate.canExecuteInline(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) booleanOLuceneSearchMoreLikeThisFunction.canExecuteInline(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) booleanOLuceneSearchOnClassFunction.canExecuteInline(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) longOLuceneSearchFunctionTemplate.estimate(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) longOLuceneSearchMoreLikeThisFunction.estimate(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) OLuceneSearchMoreLikeThisFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] params, OCommandContext ctx) OLuceneSearchOnClassFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] params, OCommandContext ctx) OLuceneSearchOnFieldsFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] params, OCommandContext ctx) OLuceneSearchOnIndexFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] params, OCommandContext ctx) protected static OLuceneFullTextIndexOLuceneFunctionsUtils.getLuceneFullTextIndex(OCommandContext ctx, String indexName) protected ODocumentOLuceneSearchFunctionTemplate.getMetadata(OExpression metadata, OCommandContext ctx) static org.apache.lucene.index.memory.MemoryIndexOLuceneFunctionsUtils.getOrCreateMemoryIndex(OCommandContext ctx) protected static OLuceneFullTextIndexOLuceneFunctionsUtils.searchForIndex(OExpression[] args, OCommandContext ctx) protected abstract OLuceneFullTextIndexOLuceneSearchFunctionTemplate.searchForIndex(OFromClause target, OCommandContext ctx, OExpression... args) protected OLuceneFullTextIndexOLuceneSearchOnClassFunction.searchForIndex(OFromClause target, OCommandContext ctx, OExpression... args) protected OLuceneFullTextIndexOLuceneSearchOnFieldsFunction.searchForIndex(OFromClause target, OCommandContext ctx, OExpression... args) protected OLuceneFullTextIndexOLuceneSearchOnIndexFunction.searchForIndex(OFromClause target, OCommandContext ctx, OExpression... args) OLuceneSearchMoreLikeThisFunction.searchFromTarget(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) OLuceneSearchOnClassFunction.searchFromTarget(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) OLuceneSearchOnFieldsFunction.searchFromTarget(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) OLuceneSearchOnIndexFunction.searchFromTarget(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) booleanOLuceneSearchFunctionTemplate.shouldExecuteAfterSearch(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) booleanOLuceneSearchMoreLikeThisFunction.shouldExecuteAfterSearch(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) -
Uses of OCommandContext in com.orientechnologies.lucene.operator
Methods in com.orientechnologies.lucene.operator with parameters of type OCommandContextModifier and TypeMethodDescriptionstatic OIndexSearchResultOLuceneOperatorUtil.buildOIndexSearchResult(OClass iSchemaClass, OSQLFilterCondition iCondition, List<OIndexSearchResult> iIndexSearchResults, OCommandContext context) OLuceneTextOperator.evaluateRecord(OIdentifiable iRecord, ODocument iCurrentResult, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext, ODocumentSerializer serializer) OLuceneTextOperator.executeIndexQuery(OCommandContext iContext, OIndex index, List<Object> keyParams, boolean ascSortOrder) OLuceneTextOperator.getOIndexSearchResult(OClass iSchemaClass, OSQLFilterCondition iCondition, List<OIndexSearchResult> iIndexSearchResults, OCommandContext context) -
Uses of OCommandContext in com.orientechnologies.lucene.query
Methods in com.orientechnologies.lucene.query that return OCommandContextConstructors in com.orientechnologies.lucene.query with parameters of type OCommandContextModifierConstructorDescriptionOLuceneQueryContext(OCommandContext context, org.apache.lucene.search.IndexSearcher searcher, org.apache.lucene.search.Query query) OLuceneQueryContext(OCommandContext context, org.apache.lucene.search.IndexSearcher searcher, org.apache.lucene.search.Query query, List<org.apache.lucene.search.SortField> sortFields) -
Uses of OCommandContext in com.orientechnologies.orient.core.command
Subinterfaces of OCommandContext in com.orientechnologies.orient.core.commandClasses in com.orientechnologies.orient.core.command that implement OCommandContextModifier and TypeClassDescriptionclassBasic implementation of OCommandContext interface that stores variables in a map.classFields in com.orientechnologies.orient.core.command declared as OCommandContextModifier and TypeFieldDescriptionprotected OCommandContextOBasicCommandContext.childprotected OCommandContextOCommandExecutorAbstract.contextprotected OCommandContextOCommandRequestAbstract.contextprotected OCommandContextOBasicCommandContext.parentMethods in com.orientechnologies.orient.core.command that return OCommandContextModifier and TypeMethodDescriptionOBasicCommandContext.copy()OCommandContext.copy()Creates a copy of execution context.OCommand.getContext()OCommandExecutor.getContext()OCommandExecutorAbstract.getContext()OCommandRequest.getContext()OCommandRequestAbstract.getContext()OBasicCommandContext.getParent()OCommandContext.getParent()OBasicCommandContext.incrementVariable(String iName) OCommandContext.incrementVariable(String getNeighbors) OBasicCommandContext.setChild(OCommandContext iContext) Set the inherited context avoiding to copy all the values every time.OCommandContext.setChild(OCommandContext context) OBasicCommandContext.setDynamicVariable(String iName, ODynamicVariable iValue) OBasicCommandContext.setParent(OCommandContext iParentContext) OCommandContext.setParent(OCommandContext iParentContext) OBasicCommandContext.setParentWithoutOverridingChild(OCommandContext iParentContext) OBasicCommandContext.setRecordingMetrics(boolean recordMetrics) OCommandContext.setRecordingMetrics(boolean recordMetrics) OBasicCommandContext.setVariable(String iName, Object iValue) OCommandContext.setVariable(String iName, Object iValue) Methods in com.orientechnologies.orient.core.command with parameters of type OCommandContextModifier and TypeMethodDescriptionstatic booleanOCommandExecutorAbstract.checkInterruption(OCommandContext iContext) OCommandPredicate.evaluate(OIdentifiable iRecord, ODocument iCurrentResult, OCommandContext iContext) Evaluates the predicate.OScriptExecutor.executeFunction(OCommandContext context, String functionName, Map<Object, Object> iArgs) OSqlScriptExecutor.executeFunction(OCommandContext context, String functionName, Map<Object, Object> iArgs) voidOBasicCommandContext.merge(OCommandContext iContext) voidOCommandContext.merge(OCommandContext iContext) Merges a context with current one.ODynamicVariable.resolve(OCommandContext contex) OBasicCommandContext.setChild(OCommandContext iContext) Set the inherited context avoiding to copy all the values every time.OCommandContext.setChild(OCommandContext context) voidOCommandExecutor.setContext(OCommandContext context) voidOCommandExecutorAbstract.setContext(OCommandContext iContext) OCommandRequest.setContext(OCommandContext iContext) OCommandRequestAbstract.setContext(OCommandContext iContext) OBasicCommandContext.setParent(OCommandContext iParentContext) OCommandContext.setParent(OCommandContext iParentContext) OBasicCommandContext.setParentWithoutOverridingChild(OCommandContext iParentContext) -
Uses of OCommandContext in com.orientechnologies.orient.core.command.script
Methods in com.orientechnologies.orient.core.command.script with parameters of type OCommandContextModifier and TypeMethodDescriptionOScriptManager.bind(ScriptEngine scriptEngine, Bindings binding, ODatabaseDocumentInternal db, OCommandContext iContext, Map<Object, Object> iArgs) Deprecated.OScriptManager.bindContextVariables(ScriptEngine engine, Bindings binding, ODatabaseDocumentInternal db, OCommandContext iContext, Map<Object, Object> iArgs) OJsr223ScriptExecutor.executeFunction(OCommandContext context, String functionName, Map<Object, Object> iArgs) OPolyglotScriptExecutor.executeFunction(OCommandContext context, String functionName, Map<Object, Object> iArgs) OCommandExecutorFunction.executeInContext(OCommandContext iContext, Map<Object, Object> iArgs) OCommandExecutorScript.executeInContext(OCommandContext iContext, Map<Object, Object> iArgs) protected ObjectOCommandExecutorScript.executeJsr223Script(String language, OCommandContext iContext, Map<Object, Object> iArgs) intOCommandExecutorScript.getTemporaryRIDCounter(OCommandContext iContext) voidOScriptManager.unbind(ScriptEngine scriptEngine, Bindings binding, OCommandContext iContext, Map<Object, Object> iArgs) Unbinds variables -
Uses of OCommandContext in com.orientechnologies.orient.core.command.traverse
Classes in com.orientechnologies.orient.core.command.traverse that implement OCommandContext -
Uses of OCommandContext in com.orientechnologies.orient.core.metadata.function
Methods in com.orientechnologies.orient.core.metadata.function with parameters of type OCommandContextModifier and TypeMethodDescriptionODatabaseFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iFuncParams, OCommandContext iContext) OFunction.executeInContext(OCommandContext iContext, Object... iArgs) Deprecated.OFunction.executeInContext(OCommandContext iContext, Map<String, Object> iArgs) Deprecated. -
Uses of OCommandContext in com.orientechnologies.orient.core.record.impl
Methods in com.orientechnologies.orient.core.record.impl with parameters of type OCommandContextModifier and TypeMethodDescriptionODocument.eval(String iExpression, OCommandContext iContext) Evaluates a SQL expression against current document by passing a context.static ObjectODocumentHelper.evaluateFunction(Object currentValue, String iFunction, OCommandContext iContext) static <RET> RETODocumentHelper.getFieldValue(Object value, String iFieldName, OCommandContext iContext) protected static ObjectODocumentHelper.getIndexPart(OCommandContext iContext, String indexPart) static voidODocumentHelper.sort(List<? extends OIdentifiable> ioResultSet, List<OPair<String, String>> iOrderCriteria, OCommandContext context) Constructors in com.orientechnologies.orient.core.record.impl with parameters of type OCommandContextModifierConstructorDescriptionODocumentComparator(List<OPair<String, String>> iOrderCriteria, OCommandContext iContext) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql
Fields in com.orientechnologies.orient.core.sql declared as OCommandContextMethods in com.orientechnologies.orient.core.sql that return OCommandContextModifier and TypeMethodDescriptionOCommandExecutorSQLDelegate.getContext()OCommandExecutorSQLTraverse.getContext()OCommandExecutorToOStatementWrapper.getContext()Methods in com.orientechnologies.orient.core.sql with parameters of type OCommandContextModifier and TypeMethodDescriptionprotected booleanOCommandExecutorSQLSelect.addResult(OIdentifiable iRecord, OCommandContext iContext) OFilterAnalyzer.analyzeCondition(OSQLFilterCondition condition, OClass schemaClass, OCommandContext context) Analyzes a query filter for a possible indexation options.OFilterAnalyzer.analyzeMainCondition(OSQLFilterCondition condition, OClass schemaClass, OCommandContext context) static ODocumentORuntimeResult.applyRecord(ODocument iValue, Map<String, Object> iProjections, OCommandContext iContext, OIdentifiable iRecord) static ODocumentOSQLHelper.bindParameters(ODocument iDocument, List<OPair<String, Object>> iFields, OCommandParameters iArguments, OCommandContext iContext) static ODocumentOSQLHelper.bindParameters(ODocument iDocument, Map<String, Object> iFields, OCommandParameters iArguments, OCommandContext iContext) protected booleanOCommandExecutorSQLResultsetAbstract.evaluateRecord(ORecord iRecord, OCommandContext iContext) protected booleanOCommandExecutorSQLSelect.executeSearchRecord(OIdentifiable id, OCommandContext iContext, boolean callHooks) protected booleanOCommandExecutorSQLResultsetAbstract.filter(ORecord iRecord, OCommandContext iContext) static ObjectOSQLEngine.foreachRecord(OCallable<Object, OIdentifiable> iCallable, Object iCurrent, OCommandContext iContext) protected ORuntimeResultOCommandExecutorSQLSelect.getProjectionGroup(Object fieldValue, OCommandContext iContext) static ODocumentORuntimeResult.getProjectionResult(int iId, Map<String, Object> iProjections, OCommandContext iContext, OIdentifiable iRecord) intOCommandExecutorSQLSelect.getTemporaryRIDCounter(OCommandContext iContext) Returns the temporary RID counter assuring it's unique per query tree.intOTemporaryRidGenerator.getTemporaryRIDCounter(OCommandContext iContext) static ObjectOSQLHelper.getValue(Object iObject, ORecord iRecord, OCommandContext iContext) protected booleanOCommandExecutorSQLResultsetAbstract.handleResult(OIdentifiable iRecord, OCommandContext iContext) protected booleanOCommandExecutorSQLSelect.handleResult(OIdentifiable iRecord, OCommandContext iContext) Handles the record in result.OSQLEngine.parseCondition(String iText, OCommandContext iContext, String iFilterKeyword) OSQLEngine.parseRIDTarget(ODatabaseDocument database, String iTarget, OCommandContext iContext, Map<Object, Object> iArgs) OSQLEngine.parseTarget(String iText, OCommandContext iContext) static ObjectOSQLHelper.parseValue(OBaseParser iCommand, String iWord, OCommandContext iContext) static ObjectOSQLHelper.parseValue(OBaseParser iCommand, String iWord, OCommandContext iContext, boolean resolveContextVariables) static ObjectOSQLHelper.parseValue(OSQLPredicate iSQLFilter, OBaseParser iCommand, String iWord, OCommandContext iContext) static ObjectOSQLHelper.parseValue(String iValue, OCommandContext iContext) Convert fields from text to real value.static ObjectOSQLHelper.parseValue(String iValue, OCommandContext iContext, boolean resolveContextVariables) static ObjectOSQLHelper.resolveFieldValue(ODocument iDocument, String iFieldName, Object iFieldValue, OCommandParameters iArguments, OCommandContext iContext) protected voidOCommandExecutorSQLSelect.revertProfiler(OCommandContext iContext, OIndex index, List<Object> keyParams, OIndexDefinition indexDefinition) protected voidOCommandExecutorSQLSelect.revertSubclassesProfiler(OCommandContext iContext, int num) voidOCommandExecutorToOStatementWrapper.setContext(OCommandContext context) voidOMetricRecorder.setContext(OCommandContext context) Constructors in com.orientechnologies.orient.core.sql with parameters of type OCommandContextModifierConstructorDescriptionOOriginalRecordsReturnHandler(Object returnExpression, OCommandContext context) protectedORecordsReturnHandler(Object returnExpression, OCommandContext context) ORuntimeResult(Object iFieldValue, Map<String, Object> iProjections, int iProgressive, OCommandContext iContext) OUpdatedRecordsReturnHandler(Object returnExpression, OCommandContext context) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.executor
Fields in com.orientechnologies.orient.core.sql.executor declared as OCommandContextMethods in com.orientechnologies.orient.core.sql.executor that return OCommandContextMethods in com.orientechnologies.orient.core.sql.executor with parameters of type OCommandContextModifier and TypeMethodDescriptionvoidAggregationContext.apply(OResult next, OCommandContext ctx) voidOFuncitonAggregationContext.apply(OResult next, OCommandContext ctx) voidOScriptExecutionPlan.chain(ORetryExecutionPlan retryStep, boolean profilingEnabled, OCommandContext ctx) voidOScriptExecutionPlan.chain(OStatement nextStm, boolean profilingEnabled, OCommandContext ctx) booleanOIfExecutionPlan.containsReturn(OCommandContext ctx) booleanOScriptExecutionPlan.containsReturn(OCommandContext ctx) booleanScriptLineStep.containsReturn(OCommandContext ctx) AccumulatingTimeoutStep.copy(OCommandContext ctx) AggregateProjectionCalculationStep.copy(OCommandContext ctx) CastToEdgeStep.copy(OCommandContext ctx) CheckClassTypeStep.copy(OCommandContext ctx) CountStep.copy(OCommandContext ctx) CreateEdgesStep.copy(OCommandContext ctx) DeleteStep.copy(OCommandContext ctx) EmptyStep.copy(OCommandContext ctx) FetchEdgesFromToVerticesStep.copy(OCommandContext ctx) FetchFromClassExecutionStep.copy(OCommandContext ctx) FetchFromClusterExecutionStep.copy(OCommandContext ctx) FetchFromIndexStep.copy(OCommandContext ctx) FetchTemporaryFromTxStep.copy(OCommandContext ctx) FilterByClassStep.copy(OCommandContext ctx) FilterStep.copy(OCommandContext ctx) GetValueFromIndexEntryStep.copy(OCommandContext ctx) GlobalLetExpressionStep.copy(OCommandContext ctx) GuaranteeEmptyCountStep.copy(OCommandContext ctx) ODeleteExecutionPlan.copy(OCommandContext ctx) default OExecutionStepOExecutionStepInternal.copy(OCommandContext ctx) OInsertExecutionPlan.copy(OCommandContext ctx) default OInternalExecutionPlanOInternalExecutionPlan.copy(OCommandContext ctx) OSelectExecutionPlan.copy(OCommandContext ctx) OUpdateExecutionPlan.copy(OCommandContext ctx) ParallelExecStep.copy(OCommandContext ctx) ProjectionCalculationStep.copy(OCommandContext ctx) SaveElementStep.copy(OCommandContext ctx) SubQueryStep.copy(OCommandContext ctx) TimeoutStep.copy(OCommandContext ctx) protected voidOSelectExecutionPlan.copyOn(OSelectExecutionPlan copy, OCommandContext ctx) intIndexSearchDescriptor.cost(OCommandContext ctx) OCreateEdgeExecutionPlanner.createExecutionPlan(OCommandContext ctx, boolean enableProfiling, boolean useCache) OCreateVertexExecutionPlanner.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) ODeleteEdgeExecutionPlanner.createExecutionPlan(OCommandContext ctx, boolean enableProfiling, boolean useCache) ODeleteExecutionPlanner.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) ODeleteVertexExecutionPlanner.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) OFindReferencesExecutionPlanner.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) OInsertExecutionPlanner.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) OMatchExecutionPlanner.createExecutionPlan(OCommandContext context, boolean enableProfiling) OMoveVertexExecutionPlanner.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) OSelectExecutionPlanner.createExecutionPlan(OCommandContext ctx, boolean enableProfiling, boolean useCache) OTraverseExecutionPlanner.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) OUpdateExecutionPlanner.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) protected Iterable<OResultInternal>MatchEdgeTraverser.executeTraversal(OCommandContext iCommandContext, OMatchPathItem item, Object startingPoint, int depth, List<OIdentifiable> pathToHere) PatternEdge.executeTraversal(OMatchStatement.MatchContext matchContext, OCommandContext iCommandContext, OIdentifiable startingPoint, int depth) ScriptLineStep.executeUntilReturn(OCommandContext ctx) protected abstract voidAbstractTraverseStep.fetchNextEntryPoints(OCommandContext ctx, int nRecords) protected voidBreadthFirstTraverseStep.fetchNextEntryPoints(OCommandContext ctx, int nRecords) protected voidDepthFirstTraverseStep.fetchNextEntryPoints(OCommandContext ctx, int nRecords) protected abstract voidAbstractTraverseStep.fetchNextResults(OCommandContext ctx, int nRecords) protected voidBreadthFirstTraverseStep.fetchNextResults(OCommandContext ctx, int nRecords) protected voidDepthFirstTraverseStep.fetchNextResults(OCommandContext ctx, int nRecords) static voidOSelectExecutionPlanner.handleOrderBy(OSelectExecutionPlan plan, QueryPlanningInfo info, OCommandContext ctx, boolean profilingEnabled) static voidOSelectExecutionPlanner.handleProjectionsBlock(OSelectExecutionPlan result, QueryPlanningInfo info, OCommandContext ctx, boolean enableProfiling) static voidOSelectExecutionPlanner.handleUnwind(OSelectExecutionPlan result, QueryPlanningInfo info, OCommandContext ctx, boolean profilingEnabled) booleanMatchEdgeTraverser.hasNext(OCommandContext ctx) voidDistributedExecutionStep.init(OCommandContext ctx) protected voidForEachStep.init(OCommandContext ctx) protected voidIfStep.init(OCommandContext ctx) protected voidMatchEdgeTraverser.init(OCommandContext ctx) protected voidOptionalMatchEdgeTraverser.init(OCommandContext ctx) voidIfStep.initNegativePlan(OCommandContext ctx) ForEachStep.initPlan(OCommandContext ctx) RetryStep.initPlan(List<OStatement> body, OCommandContext ctx) voidIfStep.initPositivePlan(OCommandContext ctx) protected OClassFetchFromClassExecutionStep.loadClassFromSchema(String className, OCommandContext ctx) protected OViewFetchFromViewExecutionStep.loadClassFromSchema(String className, OCommandContext ctx) protected booleanMatchEdgeTraverser.matchesFilters(OCommandContext iCommandContext, OWhereClause filter, OResult origin) MatchEdgeTraverser.next(OCommandContext ctx) OptionalMatchEdgeTraverser.next(OCommandContext ctx) protected static voidOSelectExecutionPlanner.optimizeQuery(QueryPlanningInfo info, OCommandContext ctx) voidODDLExecutionPlan.reset(OCommandContext ctx) voidOIfExecutionPlan.reset(OCommandContext ctx) voidOInsertExecutionPlan.reset(OCommandContext ctx) voidOInternalExecutionPlan.reset(OCommandContext ctx) voidOScriptExecutionPlan.reset(OCommandContext ctx) voidOSelectExecutionPlan.reset(OCommandContext ctx) voidOSingleOpExecutionPlan.reset(OCommandContext ctx) voidOSingleOpServerExecutionPlan.reset(OCommandContext ctx) voidOUpdateExecutionPlan.reset(OCommandContext ctx) AbstractTraverseStep.syncPull(OCommandContext ctx, int nRecords) AbstractUnrollStep.syncPull(OCommandContext ctx, int nRecords) AccumulatingTimeoutStep.syncPull(OCommandContext ctx, int nRecords) AggregateProjectionCalculationStep.syncPull(OCommandContext ctx, int nRecords) BatchStep.syncPull(OCommandContext ctx, int nRecords) CartesianProductStep.syncPull(OCommandContext ctx, int nRecords) CastToEdgeStep.syncPull(OCommandContext ctx, int nRecords) CastToVertexStep.syncPull(OCommandContext ctx, int nRecords) CheckClassTypeStep.syncPull(OCommandContext ctx, int nRecords) CheckClusterTypeStep.syncPull(OCommandContext ctx, int nRecords) CheckRecordTypeStep.syncPull(OCommandContext ctx, int nRecords) CheckSafeDeleteStep.syncPull(OCommandContext ctx, int nRecords) ConvertToResultInternalStep.syncPull(OCommandContext ctx, int nRecords) ConvertToUpdatableResultStep.syncPull(OCommandContext ctx, int nRecords) CopyDocumentStep.syncPull(OCommandContext ctx, int nRecords) CopyRecordContentBeforeUpdateStep.syncPull(OCommandContext ctx, int nRecords) CountFromClassStep.syncPull(OCommandContext ctx, int nRecords) CountFromIndexStep.syncPull(OCommandContext ctx, int nRecords) CountFromIndexWithKeyStep.syncPull(OCommandContext ctx, int nRecords) CountStep.syncPull(OCommandContext ctx, int nRecords) CreateEdgesStep.syncPull(OCommandContext ctx, int nRecords) CreateRecordStep.syncPull(OCommandContext ctx, int nRecords) DeleteFromIndexStep.syncPull(OCommandContext ctx, int nRecords) DeleteStep.syncPull(OCommandContext ctx, int nRecords) DistinctExecutionStep.syncPull(OCommandContext ctx, int nRecords) DistributedExecutionStep.syncPull(OCommandContext ctx, int nRecords) EmptyDataGeneratorStep.syncPull(OCommandContext ctx, int nRecords) EmptyStep.syncPull(OCommandContext ctx, int nRecords) ExpandStep.syncPull(OCommandContext ctx, int nRecords) FetchEdgesFromToVerticesStep.syncPull(OCommandContext ctx, int nRecords) FetchEdgesToVerticesStep.syncPull(OCommandContext ctx, int nRecords) FetchFromClassExecutionStep.syncPull(OCommandContext ctx, int nRecords) FetchFromClusterExecutionStep.syncPull(OCommandContext ctx, int nRecords) FetchFromClustersExecutionStep.syncPull(OCommandContext ctx, int nRecords) FetchFromDatabaseMetadataStep.syncPull(OCommandContext ctx, int nRecords) FetchFromDistributedMetadataStep.syncPull(OCommandContext ctx, int nRecords) FetchFromIndexedFunctionStep.syncPull(OCommandContext ctx, int nRecords) FetchFromIndexStep.syncPull(OCommandContext ctx, int nRecords) FetchFromRidsStep.syncPull(OCommandContext ctx, int nRecords) FetchFromStorageMetadataStep.syncPull(OCommandContext ctx, int nRecords) FetchFromVariableStep.syncPull(OCommandContext ctx, int nRecords) FetchTemporaryFromTxStep.syncPull(OCommandContext ctx, int nRecords) FilterByClassStep.syncPull(OCommandContext ctx, int nRecords) FilterByClustersStep.syncPull(OCommandContext ctx, int nRecords) FilterNotMatchPatternStep.syncPull(OCommandContext ctx, int nRecords) FilterStep.syncPull(OCommandContext ctx, int nRecords) FindReferencesStep.syncPull(OCommandContext ctx, int nRecords) ForEachStep.syncPull(OCommandContext ctx, int nRecords) GetValueFromIndexEntryStep.syncPull(OCommandContext ctx, int nRecords) GlobalLetExpressionStep.syncPull(OCommandContext ctx, int nRecords) GlobalLetQueryStep.syncPull(OCommandContext ctx, int nRecords) GuaranteeEmptyCountStep.syncPull(OCommandContext ctx, int nRecords) IfStep.syncPull(OCommandContext ctx, int nRecords) InsertIntoIndexStep.syncPull(OCommandContext ctx, int nRecords) InsertValuesStep.syncPull(OCommandContext ctx, int nRecords) LetExpressionStep.syncPull(OCommandContext ctx, int nRecords) LetQueryStep.syncPull(OCommandContext ctx, int nRecords) LimitExecutionStep.syncPull(OCommandContext ctx, int nRecords) LockRecordStep.syncPull(OCommandContext ctx, int nRecords) MatchFirstStep.syncPull(OCommandContext ctx, int nRecords) MatchPrefetchStep.syncPull(OCommandContext ctx, int nRecords) MatchStep.syncPull(OCommandContext ctx, int nRecords) MoveVertexStep.syncPull(OCommandContext ctx, int nRecords) OExecutionStepInternal.syncPull(OCommandContext ctx, int nRecords) OrderByStep.syncPull(OCommandContext ctx, int nRecords) ParallelExecStep.syncPull(OCommandContext ctx, int nRecords) ProjectionCalculationStep.syncPull(OCommandContext ctx, int nRecords) RemoveEdgePointersStep.syncPull(OCommandContext ctx, int nRecords) RemoveEmptyOptionalsStep.syncPull(OCommandContext ctx, int nRecords) RetryStep.syncPull(OCommandContext ctx, int nRecords) ReturnMatchPathsStep.syncPull(OCommandContext ctx, int nRecords) ReturnMatchPatternsStep.syncPull(OCommandContext ctx, int nRecords) ReturnStep.syncPull(OCommandContext ctx, int nRecords) SaveElementStep.syncPull(OCommandContext ctx, int nRecords) ScriptLineStep.syncPull(OCommandContext ctx, int nRecords) SetDocumentClassStep.syncPull(OCommandContext ctx, int nRecords) SkipExecutionStep.syncPull(OCommandContext ctx, int nRecords) SubQueryStep.syncPull(OCommandContext ctx, int nRecords) TimeoutStep.syncPull(OCommandContext ctx, int nRecords) UnwindStep.syncPull(OCommandContext ctx, int nRecords) UnwrapPreviousValueStep.syncPull(OCommandContext ctx, int nRecords) UpdateContentStep.syncPull(OCommandContext ctx, int nRecords) UpdateEdgePointersStep.syncPull(OCommandContext ctx, int nRecords) UpdateMergeStep.syncPull(OCommandContext ctx, int nRecords) UpdateRemoveStep.syncPull(OCommandContext ctx, int nRecords) UpdateSetStep.syncPull(OCommandContext ctx, int nRecords) UpsertStep.syncPull(OCommandContext ctx, int nRecords) protected StringMatchEdgeTraverser.targetClassName(OMatchPathItem item, OCommandContext iCommandContext) protected StringMatchReverseEdgeTraverser.targetClassName(OMatchPathItem item, OCommandContext iCommandContext) protected StringMatchEdgeTraverser.targetClusterName(OMatchPathItem item, OCommandContext iCommandContext) protected StringMatchReverseEdgeTraverser.targetClusterName(OMatchPathItem item, OCommandContext iCommandContext) protected ORidMatchEdgeTraverser.targetRid(OMatchPathItem item, OCommandContext iCommandContext) protected ORidMatchReverseEdgeTraverser.targetRid(OMatchPathItem item, OCommandContext iCommandContext) protected Iterable<OResultInternal>MatchEdgeTraverser.traversePatternEdge(OIdentifiable startingPoint, OCommandContext iCommandContext) protected Iterable<OResultInternal>MatchFieldTraverser.traversePatternEdge(OIdentifiable startingPoint, OCommandContext iCommandContext) protected Iterable<OResultInternal>MatchMultiEdgeTraverser.traversePatternEdge(OIdentifiable startingPoint, OCommandContext iCommandContext) protected Iterable<OResultInternal>MatchReverseEdgeTraverser.traversePatternEdge(OIdentifiable startingPoint, OCommandContext iCommandContext) protected abstract Collection<OResult>AbstractUnrollStep.unroll(OResult doc, OCommandContext iContext) protected Collection<OResult>ReturnMatchElementsStep.unroll(OResult doc, OCommandContext iContext) protected Collection<OResult>ReturnMatchPathElementsStep.unroll(OResult doc, OCommandContext iContext) protected Collection<OResult>WhileMatchStep.unroll(OResult doc, OCommandContext iContext) Constructors in com.orientechnologies.orient.core.sql.executor with parameters of type OCommandContextModifierConstructorDescriptionAbstractExecutionStep(OCommandContext ctx, boolean profilingEnabled) AbstractTraverseStep(List<OTraverseProjectionItem> projections, OWhereClause whileClause, OInteger maxDepth, OCommandContext ctx, boolean profilingEnabled) AbstractUnrollStep(OCommandContext ctx, boolean profilingEnabled) AccumulatingTimeoutStep(OTimeout timeout, OCommandContext ctx, boolean profilingEnabled) AggregateProjectionCalculationStep(OProjection projection, OGroupBy groupBy, long limit, OCommandContext ctx, long timeoutMillis, boolean profilingEnabled) BatchStep(OBatch batch, OCommandContext ctx, boolean profilingEnabled) BreadthFirstTraverseStep(List<OTraverseProjectionItem> projections, OWhereClause whileClause, OInteger maxDepth, OCommandContext ctx, boolean profilingEnabled) CartesianProductStep(OCommandContext ctx, boolean profilingEnabled) CastToEdgeStep(OCommandContext ctx, boolean profilingEnabled) CastToVertexStep(OCommandContext ctx, boolean profilingEnabled) CheckClassTypeStep(String targetClass, String parentClass, OCommandContext ctx, boolean profilingEnabled) CheckClusterTypeStep(OCluster targetCluster, String clazz, OCommandContext ctx, boolean profilingEnabled) CheckClusterTypeStep(String targetClusterName, String clazz, OCommandContext ctx, boolean profilingEnabled) CheckRecordTypeStep(OCommandContext ctx, String className, boolean profilingEnabled) CheckSafeDeleteStep(OCommandContext ctx, boolean profilingEnabled) ConvertToResultInternalStep(OCommandContext ctx, boolean profilingEnabled) ConvertToUpdatableResultStep(OCommandContext ctx, boolean profilingEnabled) CopyDocumentStep(OCommandContext ctx, boolean profilingEnabled) CopyRecordContentBeforeUpdateStep(OCommandContext ctx, boolean profilingEnabled) CountFromClassStep(OIdentifier targetClass, String alias, OCommandContext ctx, boolean profilingEnabled) CountFromIndexStep(OIndexIdentifier targetIndex, String alias, OCommandContext ctx, boolean profilingEnabled) CountFromIndexWithKeyStep(OIndexIdentifier targetIndex, OExpression keyValue, String alias, OCommandContext ctx, boolean profilingEnabled) CountStep(OCommandContext ctx, boolean profilingEnabled) CreateEdgesStep(OIdentifier targetClass, OIdentifier targetClusterName, String uniqueIndex, OIdentifier fromAlias, OIdentifier toAlias, Number wait, Number retry, OBatch batch, OCommandContext ctx, boolean profilingEnabled) CreateRecordStep(OCommandContext ctx, int total, boolean profilingEnabled, Optional<String> cl) DeleteFromIndexStep(OIndex index, OBooleanExpression condition, OBinaryCondition additionalRangeCondition, OBooleanExpression ridCondition, OCommandContext ctx, boolean profilingEnabled) DeleteStep(OCommandContext ctx, boolean profilingEnabled) DepthFirstTraverseStep(List<OTraverseProjectionItem> projections, OWhereClause whileClause, OInteger maxDepth, OCommandContext ctx, boolean profilingEnabled) DistinctExecutionStep(OCommandContext ctx, boolean profilingEnabled) DistributedExecutionStep(OSelectExecutionPlan subExecutionPlan, String nodeName, OCommandContext ctx, boolean profilingEnabled) EmptyDataGeneratorStep(int size, OCommandContext ctx, boolean profilingEnabled) EmptyStep(OCommandContext ctx, boolean profilingEnabled) ExpandStep(OCommandContext ctx, boolean profilingEnabled) FetchEdgesFromToVerticesStep(String fromAlias, String toAlias, OIdentifier targetClass, OIdentifier targetCluster, OCommandContext ctx, boolean profilingEnabled) FetchEdgesToVerticesStep(String toAlias, OIdentifier targetClass, OIdentifier targetCluster, OCommandContext ctx, boolean profilingEnabled) protectedFetchFromClassExecutionStep(OCommandContext ctx, boolean profilingEnabled) FetchFromClassExecutionStep(String className, Set<String> clusters, OCommandContext ctx, Boolean ridOrder, boolean profilingEnabled) FetchFromClassExecutionStep(String className, Set<String> clusters, QueryPlanningInfo planningInfo, OCommandContext ctx, Boolean ridOrder, boolean profilingEnabled) iterates over a class and its subclassesFetchFromClusterExecutionStep(int clusterId, OCommandContext ctx, boolean profilingEnabled) FetchFromClusterExecutionStep(int clusterId, QueryPlanningInfo queryPlanning, OCommandContext ctx, boolean profilingEnabled) FetchFromClustersExecutionStep(int[] clusterIds, OCommandContext ctx, Boolean ridOrder, boolean profilingEnabled) iterates over a class and its subclassesFetchFromDatabaseMetadataStep(OCommandContext ctx, boolean profilingEnabled) FetchFromDistributedMetadataStep(OCommandContext ctx, boolean profilingEnabled) FetchFromIndexedFunctionStep(OBinaryCondition functionCondition, OFromClause queryTarget, OCommandContext ctx, boolean profilingEnabled) FetchFromIndexStep(OIndex index, OBooleanExpression condition, OBinaryCondition additionalRangeCondition, boolean orderAsc, OCommandContext ctx, boolean profilingEnabled) FetchFromIndexStep(OIndex index, OBooleanExpression condition, OBinaryCondition additionalRangeCondition, OCommandContext ctx, boolean profilingEnabled) FetchFromIndexValuesStep(OIndex index, boolean asc, OCommandContext ctx, boolean profilingEnabled) FetchFromRidsStep(Collection<ORecordId> rids, OCommandContext ctx, boolean profilingEnabled) FetchFromStorageMetadataStep(OCommandContext ctx, boolean profilingEnabled) FetchFromVariableStep(OFromItem variableName, OCommandContext ctx, boolean profilingEnabled) FetchFromViewExecutionStep(String className, Set<String> clusters, QueryPlanningInfo planningInfo, OCommandContext ctx, Boolean ridOrder, boolean profilingEnabled) FetchTemporaryFromTxStep(OCommandContext ctx, String className, boolean profilingEnabled) FilterByClassStep(OIdentifier identifier, OCommandContext ctx, boolean profilingEnabled) FilterByClustersStep(Set<String> filterClusters, OCommandContext ctx, boolean profilingEnabled) FilterNotMatchPatternStep(List<AbstractExecutionStep> steps, OCommandContext ctx, boolean enableProfiling) FilterStep(OWhereClause whereClause, OCommandContext ctx, long timeoutMillis, boolean profilingEnabled) FindReferencesStep(List<OIdentifier> classes, List<OCluster> clusters, OCommandContext ctx, boolean profilingEnabled) ForEachStep(OIdentifier loopVariable, OExpression oExpression, List<OStatement> statements, OCommandContext ctx, boolean enableProfiling) GetValueFromIndexEntryStep(OCommandContext ctx, int[] filterClusterIds, boolean profilingEnabled) GlobalLetExpressionStep(OIdentifier varName, OExpression expression, OCommandContext ctx, boolean profilingEnabled) GlobalLetQueryStep(OIdentifier varName, OStatement query, OCommandContext ctx, boolean profilingEnabled, List<String> scriptVars) GuaranteeEmptyCountStep(OProjectionItem oProjectionItem, OCommandContext ctx, boolean enableProfiling) IfStep(OCommandContext ctx, boolean profilingEnabled) InsertIntoIndexStep(OIndexIdentifier targetIndex, OInsertBody insertBody, OCommandContext ctx, boolean profilingEnabled) InsertValuesStep(List<OIdentifier> identifierList, List<List<OExpression>> valueExpressions, OCommandContext ctx, boolean profilingEnabled) LetExpressionStep(OIdentifier varName, OExpression expression, OCommandContext ctx, boolean profilingEnabled) LetQueryStep(OIdentifier varName, OStatement query, OCommandContext ctx, boolean profilingEnabled) LimitExecutionStep(OLimit limit, OCommandContext ctx, boolean profilingEnabled) LockRecordStep(OStorage.LOCKING_STRATEGY lockStrategy, OCommandContext ctx, boolean enableProfiling) MatchFirstStep(OCommandContext context, PatternNode node, boolean profilingEnabled) MatchFirstStep(OCommandContext context, PatternNode node, OInternalExecutionPlan subPlan, boolean profilingEnabled) MatchPrefetchStep(OCommandContext ctx, OInternalExecutionPlan prefetchExecPlan, String alias, boolean profilingEnabled) MatchStep(OCommandContext context, EdgeTraversal edge, boolean profilingEnabled) MoveVertexStep(OIdentifier targetClass, OCluster targetCluster, OCommandContext ctx, boolean profilingEnabled) ODDLExecutionPlan(OCommandContext ctx, ODDLStatement stm) OIndexSearchInfo(String indexField, boolean allowsRangeQueries, boolean map, boolean indexByKey, boolean indexByValue, boolean supportNull, OCommandContext ctx) OptionalMatchStep(OCommandContext context, EdgeTraversal edge, boolean profilingEnabled) OrderByStep(OOrderBy orderBy, OCommandContext ctx, long timeoutMillis, boolean profilingEnabled) OrderByStep(OOrderBy orderBy, Integer maxResults, OCommandContext ctx, long timeoutMillis, boolean profilingEnabled) ParallelExecStep(List<OInternalExecutionPlan> subExecuitonPlans, OCommandContext ctx, boolean profilingEnabled) ProjectionCalculationStep(OProjection projection, OCommandContext ctx, boolean profilingEnabled) RemoveEdgePointersStep(OCommandContext ctx, boolean profilingEnabled) RemoveEmptyOptionalsStep(OCommandContext ctx, boolean profilingEnabled) RemoveEmptyOptionalsStep(OCommandContext ctx, OIdentifier cluster, boolean profilingEnabled) RetryStep(List<OStatement> statements, int retries, List<OStatement> elseStatements, Boolean elseFail, OCommandContext ctx, boolean enableProfiling) ReturnMatchElementsStep(OCommandContext context, boolean profilingEnabled) ReturnMatchPathElementsStep(OCommandContext context, boolean profilingEnabled) ReturnMatchPathsStep(OCommandContext context, boolean profilingEnabled) ReturnMatchPatternsStep(OCommandContext context, boolean profilingEnabled) ReturnStep(OSimpleExecStatement statement, OCommandContext ctx, boolean profilingEnabled) SaveElementStep(OCommandContext ctx, boolean profilingEnabled) SaveElementStep(OCommandContext ctx, OIdentifier cluster, boolean profilingEnabled) ScriptLineStep(OStatement statement, OCommandContext ctx, boolean profilingEnabled) SetDocumentClassStep(String targetClass, OCommandContext ctx, boolean profilingEnabled) SkipExecutionStep(OSkip skip, OCommandContext ctx, boolean profilingEnabled) SubQueryStep(OInternalExecutionPlan subExecutionPlan, OCommandContext ctx, OCommandContext subCtx, boolean profilingEnabled) executes a sub-queryTimeoutStep(OTimeout timeout, OCommandContext ctx, boolean profilingEnabled) UnwindStep(OUnwind unwind, OCommandContext ctx, boolean profilingEnabled) UnwrapPreviousValueStep(OCommandContext ctx, boolean profilingEnabled) UpdateContentStep(OInputParameter inputParameter, OCommandContext ctx, boolean profilingEnabled) UpdateContentStep(OJson json, OCommandContext ctx, boolean profilingEnabled) UpdateEdgePointersStep(OCommandContext ctx, boolean profilingEnabled) UpdateMergeStep(OJson json, OCommandContext ctx, boolean profilingEnabled) UpdateRemoveStep(List<OUpdateRemoveItem> items, OCommandContext ctx, boolean profilingEnabled) UpdateSetStep(List<OUpdateItem> updateItems, OCommandContext ctx, boolean profilingEnabled) UpsertStep(OFromClause target, OWhereClause where, OCommandContext ctx, boolean profilingEnabled) WhileMatchStep(OCommandContext ctx, OWhereClause condition, OInternalExecutionPlan body, boolean profilingEnabled) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.filter
Fields in com.orientechnologies.orient.core.sql.filter declared as OCommandContextModifier and TypeFieldDescriptionprotected OCommandContextOSQLPredicate.contextprotected final OCommandContextOSQLTarget.contextMethods in com.orientechnologies.orient.core.sql.filter with parameters of type OCommandContextModifier and TypeMethodDescriptionOSQLFilter.evaluate(OIdentifiable iRecord, ODocument iCurrentResult, OCommandContext iContext) OSQLFilterCondition.evaluate(OIdentifiable iCurrentRecord, ODocument iCurrentResult, OCommandContext iContext) protected ObjectOSQLFilterCondition.evaluate(OIdentifiable iCurrentRecord, ODocument iCurrentResult, Object iValue, OCommandContext iContext, boolean binaryEvaluation) OSQLPredicate.evaluate(OCommandContext iContext) OSQLPredicate.evaluate(OIdentifiable iRecord, ODocument iCurrentResult, OCommandContext iContext) OSQLFilterItem.getValue(OIdentifiable iRecord, Object iCurrentResult, OCommandContext iContetx) OSQLFilterItemField.getValue(OIdentifiable iRecord, Object iCurrentResult, OCommandContext iContext) OSQLFilterItemFieldMultiAbstract.getValue(OIdentifiable iRecord, Object iCurrentResult, OCommandContext iContext) OSQLFilterItemParameter.getValue(OIdentifiable iRecord, Object iCurrentResult, OCommandContext iContetx) OSQLFilterItemVariable.getValue(OIdentifiable iRecord, Object iCurrentResult, OCommandContext iContext) OSQLFilterItemAbstract.transformValue(OIdentifiable iRecord, OCommandContext iContext, Object ioResult) Constructors in com.orientechnologies.orient.core.sql.filter with parameters of type OCommandContextModifierConstructorDescriptionOSQLFilter(String iText, OCommandContext iContext, String iFilterKeyword) OSQLTarget(String iText, OCommandContext iContext) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.functions
Methods in com.orientechnologies.orient.core.sql.functions with parameters of type OCommandContextModifier and TypeMethodDescriptionbooleanOIndexableSQLFunction.allowsIndexedExecution(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) Checks if this function can be used to fetch data from this target and with these arguments (eg.booleanOIndexableSQLFunction.canExecuteInline(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) checks if the function can be used even on single records, not as an indexed function (even if the index does not exist at all)longOIndexableSQLFunction.estimate(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) estimates the number of entries returned by searchFromTarget() with these parametersOSQLFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) Process a record.OSQLFunctionFiltered.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, Iterable<OIdentifiable> iPossibleResults, OCommandContext iContext) Process a record.OSQLFunctionRuntime.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, OCommandContext iContext) Execute a function.OSQLFunctionRuntime.getValue(OIdentifiable iRecord, Object iCurrentResult, OCommandContext iContext) OIndexableSQLFunction.searchFromTarget(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) returns all the entries belonging to the target that match the binary condition where this function appearsbooleanOIndexableSQLFunction.shouldExecuteAfterSearch(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) Checks if this function should be called even if the methodOIndexableSQLFunction.searchFromTarget(com.orientechnologies.orient.core.sql.parser.OFromClause, com.orientechnologies.orient.core.sql.parser.OBinaryCompareOperator, java.lang.Object, com.orientechnologies.orient.core.command.OCommandContext, com.orientechnologies.orient.core.sql.parser.OExpression...)is executed. -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.functions.coll
Methods in com.orientechnologies.orient.core.sql.functions.coll with parameters of type OCommandContextModifier and TypeMethodDescriptionprotected ObjectOSQLFunctionTraversedElement.evaluate(Object iThis, Object[] iParams, OCommandContext iContext, String iClassName) OSQLFunctionDifference.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionDistinct.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionDocument.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionFirst.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionIntersect.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionLast.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionList.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionMap.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionSet.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionSymmetricDifference.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionTraversedEdge.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionTraversedElement.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionTraversedVertex.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionUnionAll.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLMethodMultiValue.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.functions.conversion
Methods in com.orientechnologies.orient.core.sql.functions.conversion with parameters of type OCommandContextModifier and TypeMethodDescriptionOSQLMethodAsDate.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodAsDateTime.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodAsDecimal.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodBeforeUpdate.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodConvert.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.functions.geo
Methods in com.orientechnologies.orient.core.sql.functions.geo with parameters of type OCommandContextModifier and TypeMethodDescriptionOSQLFunctionDistance.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.functions.graph
Fields in com.orientechnologies.orient.core.sql.functions.graph declared as OCommandContextModifier and TypeFieldDescriptionprotected OCommandContextOSQLFunctionHeuristicPathFinderAbstract.contextprotected OCommandContextOSQLFunctionPathFinder.contextMethods in com.orientechnologies.orient.core.sql.functions.graph with parameters of type OCommandContextModifier and TypeMethodDescriptionOSQLFunctionAstar.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionDijkstra.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionMove.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParameters, OCommandContext iContext) OSQLFunctionMoveFiltered.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParameters, Iterable<OIdentifiable> iPossibleResults, OCommandContext iContext) protected LinkedList<OVertex>OSQLFunctionPathFinder.execute(OCommandContext iContext) OSQLFunctionShortestPath.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) protected doubleOSQLFunctionHeuristicPathFinderAbstract.getCustomHeuristicCost(String functionName, String[] vertextAxisNames, OVertex start, OVertex goal, OVertex current, OVertex parent, long depth, double dFactor, OCommandContext ctx) protected doubleOSQLFunctionAstar.getHeuristicCost(OVertex node, OVertex parent, OVertex target, OCommandContext iContext) protected abstract doubleOSQLFunctionHeuristicPathFinderAbstract.getHeuristicCost(OVertex node, OVertex parent, OVertex target, OCommandContext iContext) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.functions.math
Methods in com.orientechnologies.orient.core.sql.functions.math with parameters of type OCommandContextModifier and TypeMethodDescriptionOSQLFunctionAbsoluteValue.execute(Object iThis, OIdentifiable iRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionAverage.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionDecimal.execute(Object iThis, OIdentifiable iRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionEval.execute(Object iThis, OIdentifiable iRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionInterval.execute(Object iThis, OIdentifiable iRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionMax.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionMin.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionSum.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.functions.misc
Methods in com.orientechnologies.orient.core.sql.functions.misc with parameters of type OCommandContextModifier and TypeMethodDescriptionOSQLFunctionCoalesce.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionCount.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionDate.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionDecode.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionEncode.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionFormat.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionIf.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionIfNull.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionIndexKeySize.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext context) OSQLFunctionStrcmpci.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionSysdate.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionThrowCME.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionUUID.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLMethodExclude.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodInclude.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLStaticReflectiveFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.functions.sequence
Methods in com.orientechnologies.orient.core.sql.functions.sequence with parameters of type OCommandContextModifier and TypeMethodDescriptionOSQLFunctionSequence.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.functions.stat
Methods in com.orientechnologies.orient.core.sql.functions.stat with parameters of type OCommandContextModifier and TypeMethodDescriptionOSQLFunctionMode.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionPercentile.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionVariance.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.functions.text
Methods in com.orientechnologies.orient.core.sql.functions.text with parameters of type OCommandContextModifier and TypeMethodDescriptionOSQLFunctionConcat.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionFormat.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] params, OCommandContext iContext) OSQLMethodAppend.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodFromJSON.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodHash.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodLength.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodReplace.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodRight.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodSubString.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodToJSON.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.method
Methods in com.orientechnologies.orient.core.sql.method with parameters of type OCommandContextModifier and TypeMethodDescriptionOSQLMethod.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) Process a record.OSQLMethodCharAt.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodLeft.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodRuntime.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, OCommandContext iContext) Execute a method.OSQLMethodRuntime.getValue(OIdentifiable iRecord, Object iCurrentResult, OCommandContext iContext) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.method.misc
Methods in com.orientechnologies.orient.core.sql.method.misc with parameters of type OCommandContextModifier and TypeMethodDescriptionOSQLMethodAsBoolean.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodAsFloat.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodAsInteger.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodAsList.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodAsLong.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodAsMap.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodAsSet.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodAsString.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodField.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodFormat.execute(Object iThis, OIdentifiable iRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodFunctionDelegate.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodIndexOf.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodJavaType.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodKeys.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodLastIndexOf.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodNormalize.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodPrefix.execute(Object iThis, OIdentifiable iRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodRemove.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodRemoveAll.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodSize.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodSplit.execute(Object iThis, OIdentifiable iRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodToLowerCase.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodToUpperCase.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodTrim.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodType.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodValues.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.method.sequence
Methods in com.orientechnologies.orient.core.sql.method.sequence with parameters of type OCommandContextModifier and TypeMethodDescriptionOSQLMethodCurrent.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodNext.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) OSQLMethodReset.execute(Object iThis, OIdentifiable iCurrentRecord, OCommandContext iContext, Object ioResult, Object[] iParams) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.operator
Methods in com.orientechnologies.orient.core.sql.operator with parameters of type OCommandContextModifier and TypeMethodDescriptionbooleanOQueryOperatorEquality.evaluate(OBinaryField iFirstField, OBinaryField iSecondField, OCommandContext iContext, ODocumentSerializer serializer) booleanOQueryOperatorEquals.evaluate(OBinaryField iFirstField, OBinaryField iSecondField, OCommandContext iContext, ODocumentSerializer serializer) booleanOQueryOperatorMajor.evaluate(OBinaryField iFirstField, OBinaryField iSecondField, OCommandContext iContext, ODocumentSerializer serializer) booleanOQueryOperatorMajorEquals.evaluate(OBinaryField iFirstField, OBinaryField iSecondField, OCommandContext iContext, ODocumentSerializer serializer) booleanOQueryOperatorMinor.evaluate(OBinaryField iFirstField, OBinaryField iSecondField, OCommandContext iContext, ODocumentSerializer serializer) booleanOQueryOperatorMinorEquals.evaluate(OBinaryField iFirstField, OBinaryField iSecondField, OCommandContext iContext, ODocumentSerializer serializer) booleanOQueryOperatorNotEquals.evaluate(OBinaryField iFirstField, OBinaryField iSecondField, OCommandContext iContext, ODocumentSerializer serializer) booleanOQueryOperatorNotEquals2.evaluate(OBinaryField iFirstField, OBinaryField iSecondField, OCommandContext iContext, ODocumentSerializer serializer) protected booleanOQueryOperatorBetween.evaluateExpression(OIdentifiable iRecord, OSQLFilterCondition condition, Object left, Object right, OCommandContext iContext) protected booleanOQueryOperatorContains.evaluateExpression(OIdentifiable iRecord, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext) protected booleanOQueryOperatorContainsAll.evaluateExpression(OIdentifiable iRecord, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext) protected booleanOQueryOperatorContainsKey.evaluateExpression(OIdentifiable iRecord, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext) protected booleanOQueryOperatorContainsValue.evaluateExpression(OIdentifiable iRecord, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext) protected abstract booleanOQueryOperatorEquality.evaluateExpression(OIdentifiable iRecord, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext) protected booleanOQueryOperatorEquals.evaluateExpression(OIdentifiable iRecord, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext) protected booleanOQueryOperatorIn.evaluateExpression(OIdentifiable iRecord, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext) protected booleanOQueryOperatorInstanceof.evaluateExpression(OIdentifiable iRecord, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext) protected booleanOQueryOperatorIs.evaluateExpression(OIdentifiable iRecord, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext) protected booleanOQueryOperatorLike.evaluateExpression(OIdentifiable iRecord, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext) protected booleanOQueryOperatorMajor.evaluateExpression(OIdentifiable iRecord, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext) protected booleanOQueryOperatorMajorEquals.evaluateExpression(OIdentifiable iRecord, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext) protected booleanOQueryOperatorMatches.evaluateExpression(OIdentifiable iRecord, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext) protected booleanOQueryOperatorMinor.evaluateExpression(OIdentifiable iRecord, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext) protected booleanOQueryOperatorMinorEquals.evaluateExpression(OIdentifiable iRecord, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext) protected booleanOQueryOperatorNotEquals.evaluateExpression(OIdentifiable iRecord, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext) protected booleanOQueryOperatorNotEquals2.evaluateExpression(OIdentifiable iRecord, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext) protected booleanOQueryOperatorTraverse.evaluateExpression(OIdentifiable iRecord, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext) abstract ObjectOQueryOperator.evaluateRecord(OIdentifiable iRecord, ODocument iCurrentResult, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext, ODocumentSerializer serializer) OQueryOperatorAnd.evaluateRecord(OIdentifiable iRecord, ODocument iCurrentResult, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext, ODocumentSerializer serializer) OQueryOperatorContainsText.evaluateRecord(OIdentifiable iRecord, ODocument iCurrentResult, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext, ODocumentSerializer serializer) This is executed on non-indexed fields.OQueryOperatorEquality.evaluateRecord(OIdentifiable iRecord, ODocument iCurrentResult, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext, ODocumentSerializer serializer) OQueryOperatorEqualityNotNulls.evaluateRecord(OIdentifiable iRecord, ODocument iCurrentResult, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext, ODocumentSerializer serializer) OQueryOperatorNot.evaluateRecord(OIdentifiable iRecord, ODocument iCurrentResult, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext, ODocumentSerializer serializer) OQueryOperatorOr.evaluateRecord(OIdentifiable iRecord, ODocument iCurrentResult, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext, ODocumentSerializer serializer) OQueryTargetOperator.evaluateRecord(OIdentifiable iRecord, ODocument iCurrentResult, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext, ODocumentSerializer serializer) At run-time the evaluation per record must return always true since the recordset are filtered at the beginning unless an operator can work in both modes.OQueryOperator.executeIndexQuery(OCommandContext iContext, OIndex index, List<Object> keyParams, boolean ascSortOrder) Performs index query and returns index stream which presents subset of index data which corresponds to result of execution of given operator.OQueryOperatorBetween.executeIndexQuery(OCommandContext iContext, OIndex index, List<Object> keyParams, boolean ascSortOrder) OQueryOperatorContains.executeIndexQuery(OCommandContext iContext, OIndex index, List<Object> keyParams, boolean ascSortOrder) OQueryOperatorContainsKey.executeIndexQuery(OCommandContext iContext, OIndex index, List<Object> keyParams, boolean ascSortOrder) OQueryOperatorContainsText.executeIndexQuery(OCommandContext iContext, OIndex index, List<Object> keyParams, boolean ascSortOrder) OQueryOperatorContainsValue.executeIndexQuery(OCommandContext iContext, OIndex index, List<Object> keyParams, boolean ascSortOrder) OQueryOperatorEquals.executeIndexQuery(OCommandContext iContext, OIndex index, List<Object> keyParams, boolean ascSortOrder) OQueryOperatorIn.executeIndexQuery(OCommandContext iContext, OIndex index, List<Object> keyParams, boolean ascSortOrder) OQueryOperatorIs.executeIndexQuery(OCommandContext iContext, OIndex index, List<Object> keyParams, boolean ascSortOrder) OQueryOperatorMajor.executeIndexQuery(OCommandContext iContext, OIndex index, List<Object> keyParams, boolean ascSortOrder) OQueryOperatorMajorEquals.executeIndexQuery(OCommandContext iContext, OIndex index, List<Object> keyParams, boolean ascSortOrder) OQueryOperatorMinor.executeIndexQuery(OCommandContext iContext, OIndex index, List<Object> keyParams, boolean ascSortOrder) OQueryOperatorMinorEquals.executeIndexQuery(OCommandContext iContext, OIndex index, List<Object> keyParams, boolean ascSortOrder) OQueryOperator.getOIndexSearchResult(OClass iSchemaClass, OSQLFilterCondition iCondition, List<OIndexSearchResult> iIndexSearchResults, OCommandContext context) protected voidOQueryOperator.updateProfiler(OCommandContext iContext, OIndex index, List<Object> keyParams, OIndexDefinition indexDefinition) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.operator.math
Methods in com.orientechnologies.orient.core.sql.operator.math with parameters of type OCommandContextModifier and TypeMethodDescriptionOQueryOperatorDivide.evaluateRecord(OIdentifiable iRecord, ODocument iCurrentResult, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext, ODocumentSerializer serializer) OQueryOperatorMinus.evaluateRecord(OIdentifiable iRecord, ODocument iCurrentResult, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext, ODocumentSerializer serializer) OQueryOperatorMod.evaluateRecord(OIdentifiable iRecord, ODocument iCurrentResult, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext, ODocumentSerializer serializer) OQueryOperatorMultiply.evaluateRecord(OIdentifiable iRecord, ODocument iCurrentResult, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext, ODocumentSerializer serializer) OQueryOperatorPlus.evaluateRecord(OIdentifiable iRecord, ODocument iCurrentResult, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext, ODocumentSerializer serializer) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.parser
Methods in com.orientechnologies.orient.core.sql.parser that return OCommandContextMethods in com.orientechnologies.orient.core.sql.parser with parameters of type OCommandContextModifier and TypeMethodDescriptionvoidOSuffixIdentifier.aggregate(Object value, OCommandContext ctx) booleanOBaseExpression.allowsIndexedFunctionExecutionOnTarget(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) tests if current expression is an indexed function AND that function can be used on this targetbooleanOBaseIdentifier.allowsIndexedFunctionExecutionOnTarget(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) tests if current expression is an indexed function AND that function can be used on this targetbooleanOBinaryCondition.allowsIndexedFunctionExecutionOnTarget(OFromClause target, OCommandContext context) tests if current expression involves an indexed function AND that function can be used on this targetbooleanOExpression.allowsIndexedFunctionExecutionOnTarget(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) tests if current expression is an indexed function AND that function can be used on this targetbooleanOFunctionCall.allowsIndexedFunctionExecutionOnTarget(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) tests if current function is an indexed function AND that function can be used on this targetbooleanOLevelZeroIdentifier.allowsIndexedFunctionExecutionOnTarget(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) tests if current expression is an indexed function AND that function can be used on this targetbooleanOMathExpression.allowsIndexedFunctionExecutionOnTarget(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) tests if current expression is an indexed function AND that function can be used on this targetbooleanOValueExpression.allowsIndexedFunctionExecutionOnTarget(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) ONestedProjection.apply(OExpression expression, Object input, OCommandContext ctx) voidOUpdateItem.applyOperation(OResultInternal doc, OIdentifier attrName, Object rightValue, OCommandContext ctx) voidOArrayRangeSelector.applyRemove(Object currentValue, OResultInternal originalRecord, OCommandContext ctx) voidOArraySingleValuesSelector.applyRemove(Object currentValue, OResultInternal originalRecord, OCommandContext ctx) voidOBaseExpression.applyRemove(OResultInternal result, OCommandContext ctx) voidOBaseIdentifier.applyRemove(OResultInternal result, OCommandContext ctx) voidOExpression.applyRemove(OResultInternal result, OCommandContext ctx) voidOMathExpression.applyRemove(OResultInternal result, OCommandContext ctx) voidOModifier.applyRemove(Object currentValue, OResultInternal originalRecord, OCommandContext ctx) voidOOrBlock.applyRemove(Object currentValue, OResultInternal originalRecord, OCommandContext ctx) voidOParenthesisExpression.applyRemove(OResultInternal result, OCommandContext ctx) voidORightBinaryCondition.applyRemove(Object currentValue, OResultInternal originalRecord, OCommandContext ctx) voidOSuffixIdentifier.applyRemove(Object currentValue, OCommandContext ctx) voidOValueExpression.applyRemove(OResultInternal result, OCommandContext ctx) voidOUpdateItem.applyUpdate(OResultInternal doc, OCommandContext ctx) voidOUpdateRemoveItem.applyUpdate(OResultInternal result, OCommandContext ctx) OProjection.calculateExpand(OCommandContext iContext, OResult iRecord) OProjection.calculateSingle(OCommandContext iContext, OResult iRecord) booleanOBaseExpression.canExecuteIndexedFunctionWithoutIndex(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) tests if current expression is an indexed funciton AND that function can also be executed without using the indexbooleanOBaseIdentifier.canExecuteIndexedFunctionWithoutIndex(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) tests if current expression is an indexed funciton AND that function can also be executed without using the indexbooleanOBinaryCondition.canExecuteIndexedFunctionWithoutIndex(OFromClause target, OCommandContext context) tests if current expression involves an indexed funciton AND that function can also be executed without using the indexbooleanOExpression.canExecuteIndexedFunctionWithoutIndex(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) tests if current expression is an indexed function AND that function can also be executed without using the indexbooleanOFunctionCall.canExecuteIndexedFunctionWithoutIndex(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) tests if current function is an indexed function AND that function can also be executed without using the indexbooleanOLevelZeroIdentifier.canExecuteIndexedFunctionWithoutIndex(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) tests if current expression is an indexed funciton AND that function can also be executed without using the indexbooleanOMathExpression.canExecuteIndexedFunctionWithoutIndex(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) tests if current expression is an indexed funciton AND that function can also be executed without using the indexbooleanOValueExpression.canExecuteIndexedFunctionWithoutIndex(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) intOOrderBy.compare(OResult a, OResult b, OCommandContext ctx) intOOrderByItem.compare(OResult a, OResult b, OCommandContext ctx) static ObjectOUpdateItem.convertToPropertyType(OResultInternal res, OIdentifier attrName, Object newValue, OCommandContext ctx) OCreateEdgeStatement.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) OCreateVertexStatement.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) ODDLStatement.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) ODeleteEdgeStatement.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) ODeleteStatement.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) ODeleteVertexStatement.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) OExplainStatement.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) OFindReferencesStatement.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) OForEachBlock.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) OIfStatement.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) OInsertStatement.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) OMatchStatement.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) OMoveVertexStatement.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) OProfileStatement.createExecutionPlan(OCommandContext ctx, boolean profile) OSelectStatement.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) OSimpleExecStatement.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) OStatement.createExecutionPlan(OCommandContext ctx) creates an execution plan for current statement, with profiling disabledOStatement.createExecutionPlan(OCommandContext ctx, boolean profile) creates an execution plan for current statementOTraverseStatement.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) OUpdateEdgeStatement.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) OUpdateStatement.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) OWhileBlock.createExecutionPlan(OCommandContext ctx, boolean enableProfiling) OCreateEdgeStatement.createExecutionPlanNoCache(OCommandContext ctx, boolean enableProfiling) ODeleteEdgeStatement.createExecutionPlanNoCache(OCommandContext ctx, boolean enableProfiling) OSelectStatement.createExecutionPlanNoCache(OCommandContext ctx, boolean enableProfiling) OStatement.createExecutionPlanNoCache(OCommandContext ctx, boolean profile) longOWhereClause.estimate(OClass oClass, long threshold, OCommandContext ctx) estimates how many items of this class will be returned applying this filterlongOBinaryCondition.estimateIndexed(OFromClause target, OCommandContext context) longOBaseExpression.estimateIndexedFunction(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) longOBaseIdentifier.estimateIndexedFunction(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) longOExpression.estimateIndexedFunction(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) longOFunctionCall.estimateIndexedFunction(OFromClause target, OCommandContext ctx, OBinaryCompareOperator operator, Object rightValue) longOLevelZeroIdentifier.estimateIndexedFunction(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) longOMathExpression.estimateIndexedFunction(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) booleanOAndBlock.evaluate(OIdentifiable currentRecord, OCommandContext ctx) booleanOAndBlock.evaluate(OResult currentRecord, OCommandContext ctx) OBatch.evaluate(OCommandContext ctx) booleanOBetweenCondition.evaluate(OIdentifiable currentRecord, OCommandContext ctx) booleanOBetweenCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOBinaryCondition.evaluate(OIdentifiable currentRecord, OCommandContext ctx) booleanOBinaryCondition.evaluate(OResult currentRecord, OCommandContext ctx) abstract booleanOBooleanExpression.evaluate(OIdentifiable currentRecord, OCommandContext ctx) abstract booleanOBooleanExpression.evaluate(OResult currentRecord, OCommandContext ctx) booleanOContainsAllCondition.evaluate(OIdentifiable currentRecord, OCommandContext ctx) booleanOContainsAllCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOContainsAnyCondition.evaluate(OIdentifiable currentRecord, OCommandContext ctx) booleanOContainsAnyCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOContainsCondition.evaluate(OIdentifiable currentRecord, OCommandContext ctx) booleanOContainsCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOContainsTextCondition.evaluate(OIdentifiable currentRecord, OCommandContext ctx) booleanOContainsTextCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOContainsValueCondition.evaluate(OIdentifiable currentRecord, OCommandContext ctx) booleanOContainsValueCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOInCondition.evaluate(OIdentifiable currentRecord, OCommandContext ctx) booleanOInCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOInstanceofCondition.evaluate(OIdentifiable currentRecord, OCommandContext ctx) booleanOInstanceofCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOIsDefinedCondition.evaluate(OIdentifiable currentRecord, OCommandContext ctx) booleanOIsDefinedCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOIsNotDefinedCondition.evaluate(OIdentifiable currentRecord, OCommandContext ctx) booleanOIsNotDefinedCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOIsNotNullCondition.evaluate(OIdentifiable currentRecord, OCommandContext ctx) booleanOIsNotNullCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOIsNullCondition.evaluate(OIdentifiable currentRecord, OCommandContext ctx) booleanOIsNullCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOMatchesCondition.evaluate(OIdentifiable currentRecord, OCommandContext ctx) booleanOMatchesCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanONotBlock.evaluate(OIdentifiable currentRecord, OCommandContext ctx) booleanONotBlock.evaluate(OResult currentRecord, OCommandContext ctx) booleanONotInCondition.evaluate(OIdentifiable currentRecord, OCommandContext ctx) booleanONotInCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOOrBlock.evaluate(OIdentifiable currentRecord, OCommandContext ctx) booleanOOrBlock.evaluate(OResult currentRecord, OCommandContext ctx) booleanOOrBlock.evaluate(Object currentRecord, OCommandContext ctx) booleanOParenthesisBlock.evaluate(OIdentifiable currentRecord, OCommandContext ctx) booleanOParenthesisBlock.evaluate(OResult currentRecord, OCommandContext ctx) ORecordAttribute.evaluate(OElement iCurrentRecord, OCommandContext ctx) ORecordAttribute.evaluate(OResult iCurrentRecord, OCommandContext ctx) OInCondition.evaluateLeft(OIdentifiable currentRecord, OCommandContext ctx) OInCondition.evaluateLeft(OResult currentRecord, OCommandContext ctx) OInCondition.evaluateRight(OIdentifiable currentRecord, OCommandContext ctx) OInCondition.evaluateRight(OResult currentRecord, OCommandContext ctx) ORightBinaryCondition.evaluateRight(OIdentifiable currentRecord, OCommandContext ctx) ORightBinaryCondition.evaluateRight(OResult currentRecord, OCommandContext ctx) OArrayConcatExpression.execute(OIdentifiable iCurrentRecord, OCommandContext ctx) OArrayConcatExpression.execute(OResult iCurrentRecord, OCommandContext ctx) OArrayRangeSelector.execute(OIdentifiable iCurrentRecord, Object result, OCommandContext ctx) OArrayRangeSelector.execute(OResult iCurrentRecord, Object result, OCommandContext ctx) OArraySingleValuesSelector.execute(OIdentifiable iCurrentRecord, Object iResult, OCommandContext ctx) OArraySingleValuesSelector.execute(OResult iCurrentRecord, Object iResult, OCommandContext ctx) OBaseExpression.execute(OIdentifiable iCurrentRecord, OCommandContext ctx) OBaseExpression.execute(OResult iCurrentRecord, OCommandContext ctx) OBaseIdentifier.execute(OIdentifiable iCurrentRecord, OCommandContext ctx) OBaseIdentifier.execute(OResult iCurrentRecord, OCommandContext ctx) OCollection.execute(OIdentifiable iCurrentRecord, OCommandContext ctx) OCollection.execute(OResult iCurrentRecord, OCommandContext ctx) OCreateEdgeStatement.execute(ODatabaseSession db, Object[] args, OCommandContext parentCtx, boolean usePlanCache) OCreateEdgeStatement.execute(ODatabaseSession db, Map params, OCommandContext parentCtx, boolean usePlanCache) OCreateVertexStatement.execute(ODatabaseSession db, Object[] args, OCommandContext parentCtx, boolean usePlanCache) OCreateVertexStatement.execute(ODatabaseSession db, Map params, OCommandContext parentCtx, boolean usePlanCache) ODDLStatement.execute(ODatabaseSession db, Object[] args, OCommandContext parentCtx, boolean usePlanCache) ODDLStatement.execute(ODatabaseSession db, Map params, OCommandContext parentCtx, boolean usePlanCache) ODeleteEdgeStatement.execute(ODatabaseSession db, Object[] args, OCommandContext parentCtx, boolean usePlanCache) ODeleteEdgeStatement.execute(ODatabaseSession db, Map params, OCommandContext parentCtx, boolean usePlanCache) ODeleteStatement.execute(ODatabaseSession db, Object[] args, OCommandContext parentCtx, boolean usePlanCache) ODeleteStatement.execute(ODatabaseSession db, Map params, OCommandContext parentCtx, boolean usePlanCache) ODeleteVertexStatement.execute(ODatabaseSession db, Object[] args, OCommandContext parentCtx, boolean usePlanCache) ODeleteVertexStatement.execute(ODatabaseSession db, Map params, OCommandContext parentCtx, boolean usePlanCache) OExplainStatement.execute(ODatabaseSession db, Object[] args, OCommandContext parentCtx, boolean usePlanCache) OExplainStatement.execute(ODatabaseSession db, Map args, OCommandContext parentCtx, boolean usePlanCache) OExpression.execute(OIdentifiable iCurrentRecord, OCommandContext ctx) OExpression.execute(OResult iCurrentRecord, OCommandContext ctx) OFindReferencesStatement.execute(ODatabaseSession db, Object[] args, OCommandContext parentCtx, boolean usePlanCache) OFindReferencesStatement.execute(ODatabaseSession db, Map params, OCommandContext parentCtx, boolean usePlanCache) OForEachBlock.execute(ODatabaseSession db, Object[] args, OCommandContext parentCtx, boolean usePlanCache) OForEachBlock.execute(ODatabaseSession db, Map params, OCommandContext parentCtx, boolean usePlanCache) OFunctionCall.execute(Object targetObjects, OCommandContext ctx) OHaRemoveServerStatement.execute(ODatabaseSession db, Object[] args, OCommandContext parentContext, boolean usePlanCache) OHaRemoveServerStatement.execute(ODatabaseSession db, Map args, OCommandContext parentContext, boolean usePlanCache) OIfStatement.execute(ODatabaseSession db, Object[] args, OCommandContext parentCtx, boolean usePlanCache) OIfStatement.execute(ODatabaseSession db, Map params, OCommandContext parentCtx, boolean usePlanCache) OInsertStatement.execute(ODatabaseSession db, Object[] args, OCommandContext parentCtx, boolean usePlanCache) OInsertStatement.execute(ODatabaseSession db, Map params, OCommandContext parentCtx, boolean usePlanCache) OLevelZeroIdentifier.execute(OIdentifiable iCurrentRecord, OCommandContext ctx) OLevelZeroIdentifier.execute(OResult iCurrentRecord, OCommandContext ctx) OMatchStatement.execute(ODatabaseSession db, Object[] args, OCommandContext parentCtx, boolean usePlanCache) OMatchStatement.execute(ODatabaseSession db, Map params, OCommandContext parentCtx, boolean usePlanCache) OMatchStatement.execute(OSQLAsynchQuery<ODocument> request, OCommandContext context, OProgressListener progressListener) executes the match statement.OMathExpression.execute(OIdentifiable iCurrentRecord, OCommandContext ctx) OMathExpression.execute(OResult iCurrentRecord, OCommandContext ctx) OMethodCall.execute(Object targetObjects, OCommandContext ctx) OMethodCall.execute(Object targetObjects, Iterable<OIdentifiable> iPossibleResults, OCommandContext ctx) OModifier.execute(OIdentifiable iCurrentRecord, Object result, OCommandContext ctx) OModifier.execute(OResult iCurrentRecord, Object result, OCommandContext ctx) OMoveVertexStatement.execute(ODatabaseSession db, Object[] args, OCommandContext parentCtx, boolean usePlanCache) OMoveVertexStatement.execute(ODatabaseSession db, Map params, OCommandContext parentCtx, boolean usePlanCache) OParenthesisExpression.execute(OIdentifiable iCurrentRecord, OCommandContext ctx) OParenthesisExpression.execute(OResult iCurrentRecord, OCommandContext ctx) OProfileStatement.execute(ODatabaseSession db, Object[] args, OCommandContext parentCtx, boolean usePlanCache) OProfileStatement.execute(ODatabaseSession db, Map args, OCommandContext parentCtx, boolean usePlanCache) OProfileStorageStatement.execute(OSQLAsynchQuery<ODocument> request, OCommandContext context, OProgressListener progressListener) OProjectionItem.execute(OIdentifiable iCurrentRecord, OCommandContext ctx) OProjectionItem.execute(OResult iCurrentRecord, OCommandContext ctx) ORightBinaryCondition.execute(OIdentifiable iCurrentRecord, Object elementToFilter, OCommandContext ctx) ORightBinaryCondition.execute(OResult iCurrentRecord, Object elementToFilter, OCommandContext ctx) OSelectStatement.execute(ODatabaseSession db, Object[] args, OCommandContext parentCtx, boolean usePlanCache) OSelectStatement.execute(ODatabaseSession db, Map params, OCommandContext parentCtx, boolean usePlanCache) OSimpleExecStatement.execute(ODatabaseSession db, Object[] args, OCommandContext parentContext, boolean usePlanCache) OSimpleExecStatement.execute(ODatabaseSession db, Map params, OCommandContext parentContext, boolean usePlanCache) OStatement.execute(ODatabaseSession db, Object[] args, OCommandContext parentContext) OStatement.execute(ODatabaseSession db, Object[] args, OCommandContext parentContext, boolean usePlanCache) OStatement.execute(ODatabaseSession db, Map args, OCommandContext parentContext) OStatement.execute(ODatabaseSession db, Map args, OCommandContext parentContext, boolean usePlanCache) OStatement.execute(OSQLAsynchQuery<ODocument> request, OCommandContext context, OProgressListener progressListener) OSuffixIdentifier.execute(OCommandContext iCurrentRecord) OSuffixIdentifier.execute(OIdentifiable iCurrentRecord, OCommandContext ctx) OSuffixIdentifier.execute(OResult iCurrentRecord, OCommandContext ctx) OSuffixIdentifier.execute(Iterable iterable, OCommandContext ctx) OSuffixIdentifier.execute(Object currentValue, OCommandContext ctx) OSuffixIdentifier.execute(Iterator iterator, OCommandContext ctx) OSuffixIdentifier.execute(Map iCurrentRecord, OCommandContext ctx) OTraverseProjectionItem.execute(OResult iCurrentRecord, OCommandContext ctx) OTraverseStatement.execute(ODatabaseSession db, Object[] args, OCommandContext parentCtx, boolean usePlanCache) OTraverseStatement.execute(ODatabaseSession db, Map params, OCommandContext parentCtx, boolean usePlanCache) OUpdateStatement.execute(ODatabaseSession db, Object[] args, OCommandContext parentCtx, boolean usePlanCache) OUpdateStatement.execute(ODatabaseSession db, Map params, OCommandContext parentCtx, boolean usePlanCache) OValueExpression.execute(OIdentifiable iCurrentRecord, OCommandContext ctx) OValueExpression.execute(OResult iCurrentRecord, OCommandContext ctx) OWhileBlock.execute(ODatabaseSession db, Object[] args, OCommandContext parentCtx, boolean usePlanCache) OWhileBlock.execute(ODatabaseSession db, Map params, OCommandContext parentCtx, boolean usePlanCache) voidODatabaseUserData.executeCreate(ODatabaseDocumentInternal db, OCommandContext parentCtx) OAlterClassStatement.executeDDL(OCommandContext ctx) OAlterClusterStatement.executeDDL(OCommandContext ctx) OAlterDatabaseStatement.executeDDL(OCommandContext ctx) OAlterPropertyStatement.executeDDL(OCommandContext ctx) OAlterSequenceStatement.executeDDL(OCommandContext ctx) OCreateClassStatement.executeDDL(OCommandContext ctx) OCreateClusterStatement.executeDDL(OCommandContext ctx) OCreateIndexStatement.executeDDL(OCommandContext ctx) OCreatePropertyStatement.executeDDL(OCommandContext ctx) OCreateViewStatement.executeDDL(OCommandContext ctx) abstract OResultSetODDLStatement.executeDDL(OCommandContext ctx) ODropClassStatement.executeDDL(OCommandContext ctx) ODropClusterStatement.executeDDL(OCommandContext ctx) ODropIndexStatement.executeDDL(OCommandContext ctx) ODropPropertyStatement.executeDDL(OCommandContext ctx) ODropSequenceStatement.executeDDL(OCommandContext ctx) ODropViewStatement.executeDDL(OCommandContext ctx) OTruncateClassStatement.executeDDL(OCommandContext ctx) OTruncateClusterStatement.executeDDL(OCommandContext ctx) OBaseExpression.executeIndexedFunction(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) OBaseIdentifier.executeIndexedFunction(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) OBinaryCondition.executeIndexedFunction(OFromClause target, OCommandContext context) OExpression.executeIndexedFunction(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) OFunctionCall.executeIndexedFunction(OFromClause target, OCommandContext ctx, OBinaryCompareOperator operator, Object rightValue) see OIndexableSQLFunction.searchFromTarget()OLevelZeroIdentifier.executeIndexedFunction(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) OMathExpression.executeIndexedFunction(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) booleanOBaseExpression.executeIndexedFunctionAfterIndexSearch(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) tests if current expression is an indexed function AND the function has also to be executed after the index search.booleanOBaseIdentifier.executeIndexedFunctionAfterIndexSearch(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) tests if current expression is an indexed function AND the function has also to be executed after the index search.booleanOBinaryCondition.executeIndexedFunctionAfterIndexSearch(OFromClause target, OCommandContext context) tests if current expression involves an indexed function AND the function has also to be executed after the index search.booleanOExpression.executeIndexedFunctionAfterIndexSearch(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) tests if current expression is an indexed function AND the function has also to be executed after the index search.booleanOFunctionCall.executeIndexedFunctionAfterIndexSearch(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) tests if current expression is an indexed function AND the function has also to be executed after the index search.booleanOLevelZeroIdentifier.executeIndexedFunctionAfterIndexSearch(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) tests if current expression is an indexed function AND the function has also to be executed after the index search.booleanOMathExpression.executeIndexedFunctionAfterIndexSearch(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) tests if current expression is an indexed function AND the function has also to be executed after the index search.booleanOValueExpression.executeIndexedFunctionAfterIndexSearch(OFromClause target, OCommandContext context, OBinaryCompareOperator operator, Object right) protected static ObjectOInCondition.executeQuery(OSelectStatement rightStatement, OCommandContext ctx) OMethodCall.executeReverse(Object targetObjects, OCommandContext ctx) OAlterRoleStatement.executeSimple(OCommandContext ctx) OAlterSecurityPolicyStatement.executeSimple(OCommandContext ctx) OBeginStatement.executeSimple(OCommandContext ctx) OCommitStatement.executeSimple(OCommandContext ctx) OConsoleStatement.executeSimple(OCommandContext ctx) OCreateFunctionStatement.executeSimple(OCommandContext ctx) OCreateLinkStatement.executeSimple(OCommandContext ctx) OCreateSecurityPolicyStatement.executeSimple(OCommandContext ctx) OCreateSequenceStatement.executeSimple(OCommandContext ctx) OCreateUserStatement.executeSimple(OCommandContext ctx) ODropUserStatement.executeSimple(OCommandContext ctx) OExpressionStatement.executeSimple(OCommandContext ctx) OGrantStatement.executeSimple(OCommandContext ctx) OHaSetStatement.executeSimple(OCommandContext ctx) OHaStatusStatement.executeSimple(OCommandContext ctx) OHaSyncClusterStatement.executeSimple(OCommandContext ctx) OHaSyncDatabaseStatement.executeSimple(OCommandContext ctx) OLetStatement.executeSimple(OCommandContext ctx) OOptimizeDatabaseStatement.executeSimple(OCommandContext ctx) OProfileStorageStatement.executeSimple(OCommandContext ctx) ORebuildIndexStatement.executeSimple(OCommandContext ctx) OReturnStatement.executeSimple(OCommandContext ctx) ORevokeStatement.executeSimple(OCommandContext ctx) ORollbackStatement.executeSimple(OCommandContext ctx) abstract OResultSetOSimpleExecStatement.executeSimple(OCommandContext ctx) OSleepStatement.executeSimple(OCommandContext ctx) OTruncateRecordStatement.executeSimple(OCommandContext ctx) OMatchPathItem.executeTraversal(OMatchStatement.MatchContext matchContext, OCommandContext iCommandContext, OIdentifiable startingPoint, int depth) ONestedProjectionItem.expand(OExpression expression, String name, Object value, OCommandContext ctx, int recursion) OWhereClause.fetchFromIndexes(OClass oClass, OCommandContext ctx) static OExecutionPlanOExecutionPlanCache.get(String statement, OCommandContext ctx, ODatabaseDocumentInternal db) returns an already prepared SQL execution plan, taking it from the cache if it exists or creating a new one if it doesn'tOArrayConcatExpression.getAggregationContext(OCommandContext ctx) OBaseExpression.getAggregationContext(OCommandContext ctx) OBaseIdentifier.getAggregationContext(OCommandContext ctx) OExpression.getAggregationContext(OCommandContext ctx) OFunctionCall.getAggregationContext(OCommandContext ctx) OLevelZeroIdentifier.getAggregationContext(OCommandContext ctx) OMathExpression.getAggregationContext(OCommandContext ctx) OProjectionItem.getAggregationContext(OCommandContext ctx) OSuffixIdentifier.getAggregationContext(OCommandContext ctx) OValueExpression.getAggregationContext(OCommandContext ctx) OMatchFilter.getClassName(OCommandContext context) OMatchFilter.getClusterName(OCommandContext context) OBaseExpression.getCollate(OResult currentRecord, OCommandContext ctx) OBaseIdentifier.getCollate(OResult currentRecord, OCommandContext ctx) OExpression.getCollate(OResult currentRecord, OCommandContext ctx) OMathExpression.getCollate(OResult currentRecord, OCommandContext ctx) OSuffixIdentifier.getCollate(OResult currentRecord, OCommandContext ctx) OValueExpression.getCollate(OResult currentRecord, OCommandContext ctx) OExecutionPlanCache.getInternal(String statement, OCommandContext ctx, ODatabaseDocumentInternal db) OMatchFilter.getRid(OCommandContext context) OArrayNumberSelector.getValue(OIdentifiable iCurrentRecord, Object iResult, OCommandContext ctx) OArrayNumberSelector.getValue(OResult iCurrentRecord, Object iResult, OCommandContext ctx) OArraySelector.getValue(OIdentifiable iCurrentRecord, Object iResult, OCommandContext ctx) OArraySelector.getValue(OResult iCurrentRecord, Object iResult, OCommandContext ctx) intOLimit.getValue(OCommandContext ctx) intOSkip.getValue(OCommandContext ctx) static OSelectStatementOBetweenCondition.indexChainToStatement(OModifier modifier, OClass clazz, OExpression second, OExpression third, OCommandContext ctx) static OSelectStatementOBinaryCondition.indexChainToStatement(OModifier modifier, OClass clazz, OExpression right, OCommandContext ctx, OBinaryCompareOperator operator) static OSelectStatementOInCondition.indexChainToStatement(OModifier modifier, OClass clazz, OMathExpression right, OCommandContext ctx) WhileStep.initPlan(OCommandContext ctx) booleanOArrayConcatExpression.isEarlyCalculated(OCommandContext ctx) booleanOBaseExpression.isEarlyCalculated(OCommandContext ctx) booleanOBaseIdentifier.isEarlyCalculated(OCommandContext ctx) booleanOCollection.isEarlyCalculated(OCommandContext ctx) booleanOExpression.isEarlyCalculated(OCommandContext ctx) booleanOFunctionCall.isEarlyCalculated(OCommandContext ctx) booleanOIdentifier.isEarlyCalculated(OCommandContext ctx) booleanOLevelZeroIdentifier.isEarlyCalculated(OCommandContext ctx) booleanOMathExpression.isEarlyCalculated(OCommandContext ctx) booleanOParenthesisExpression.isEarlyCalculated(OCommandContext ctx) booleanOSuffixIdentifier.isEarlyCalculated(OCommandContext ctx) booleanOBetweenCondition.isIndexAware(OIndexSearchInfo info, OCommandContext ctx) booleanOBinaryCondition.isIndexAware(OIndexSearchInfo info, OCommandContext ctx) booleanOBooleanExpression.isIndexAware(OIndexSearchInfo info, OCommandContext ctx) booleanOContainsAnyCondition.isIndexAware(OIndexSearchInfo info, OCommandContext ctx) booleanOContainsValueCondition.isIndexAware(OIndexSearchInfo info, OCommandContext ctx) booleanOInCondition.isIndexAware(OIndexSearchInfo info, OCommandContext ctx) booleanOIsNullCondition.isIndexAware(OIndexSearchInfo info, OCommandContext ctx) booleanOBaseExpression.isIndexChain(OCommandContext ctx, OClass clazz) booleanOBaseIdentifier.isIndexChain(OCommandContext ctx, OClass clazz) booleanOExpression.isIndexChain(OCommandContext ctx, OClass clazz) booleanOMathExpression.isIndexChain(OCommandContext ctx, OClass clazz) booleanOModifier.isIndexChain(OCommandContext ctx, OClass clazz) booleanOWhereClause.matchesFilters(OIdentifiable currentRecord, OCommandContext ctx) booleanOWhereClause.matchesFilters(OResult currentRecord, OCommandContext ctx) OAndBlock.rewriteIndexChainsAsSubqueries(OCommandContext ctx, OClass clazz) OBetweenCondition.rewriteIndexChainsAsSubqueries(OCommandContext ctx, OClass clazz) OBinaryCondition.rewriteIndexChainsAsSubqueries(OCommandContext ctx, OClass clazz) OBooleanExpression.rewriteIndexChainsAsSubqueries(OCommandContext ctx, OClass clazz) OContainsAnyCondition.rewriteIndexChainsAsSubqueries(OCommandContext ctx, OClass clazz) OInCondition.rewriteIndexChainsAsSubqueries(OCommandContext ctx, OClass clazz) ONotBlock.rewriteIndexChainsAsSubqueries(OCommandContext ctx, OClass clazz) OOrBlock.rewriteIndexChainsAsSubqueries(OCommandContext ctx, OClass clazz) voidOMatchStatement.setContext(OCommandContext context) OCreatePropertyAttributeStatement.setOnProperty(OPropertyImpl internalProp, OCommandContext ctx) voidOArrayRangeSelector.setValue(Object target, Object value, OCommandContext ctx) voidOArrayRangeSelector.setValue(List target, Object value, OCommandContext ctx) voidOArrayRangeSelector.setValue(Map target, Object value, OCommandContext ctx) voidOArrayRangeSelector.setValue(Set target, Object value, OCommandContext ctx) voidOArraySelector.setValue(OResult currentRecord, Object target, Object value, OCommandContext ctx) voidOArraySelector.setValue(List target, int idx, Object value, OCommandContext ctx) voidOArraySelector.setValue(Map target, Object idx, Object value, OCommandContext ctx) voidOArraySelector.setValue(Set target, int idx, Object value, OCommandContext ctx) voidOArraySingleValuesSelector.setValue(OResult currentRecord, Object target, Object value, OCommandContext ctx) protected voidOModifier.setValue(OResult currentRecord, Object target, Object value, OCommandContext ctx) voidOSuffixIdentifier.setValue(OIdentifiable target, Object value, OCommandContext ctx) voidOSuffixIdentifier.setValue(OResult target, Object value, OCommandContext ctx) voidOSuffixIdentifier.setValue(Object target, Object value, OCommandContext ctx) voidOSuffixIdentifier.setValue(Map target, Object value, OCommandContext ctx) OBaseExpression.splitForAggregation(AggregateProjectionSplit aggregateProj, OCommandContext ctx) OBaseIdentifier.splitForAggregation(AggregateProjectionSplit aggregateProj, OCommandContext ctx) OCollection.splitForAggregation(AggregateProjectionSplit aggregateProj, OCommandContext ctx) OExpression.splitForAggregation(AggregateProjectionSplit aggregateSplit, OCommandContext ctx) OFunctionCall.splitForAggregation(AggregateProjectionSplit aggregateProj, OCommandContext ctx) OJson.splitForAggregation(AggregateProjectionSplit aggregateSplit, OCommandContext ctx) OJsonItem.splitForAggregation(AggregateProjectionSplit aggregateSplit, OCommandContext ctx) OLevelZeroIdentifier.splitForAggregation(AggregateProjectionSplit aggregateProj, OCommandContext ctx) OMathExpression.splitForAggregation(AggregateProjectionSplit aggregateProj, OCommandContext ctx) OParenthesisExpression.splitForAggregation(AggregateProjectionSplit aggregateProj, OCommandContext ctx) OProjectionItem.splitForAggregation(AggregateProjectionSplit aggregateSplit, OCommandContext ctx) INTERNAL USE ONLY this has to be invoked ONLY if the item is aggregate!!!WhileStep.syncPull(OCommandContext ctx, int nRecords) OJson.toDocument(OIdentifiable source, OCommandContext ctx) OJson.toMap(OIdentifiable source, OCommandContext ctx) OJson.toMap(OResult source, OCommandContext ctx) OJson.toObjectDetermineType(OIdentifiable source, OCommandContext ctx) OJson.toObjectDetermineType(OResult source, OCommandContext ctx) choosing return type is based on existence of @class and @type field in JSONORid.toRecordId(OIdentifiable target, OCommandContext ctx) ORid.toRecordId(OResult target, OCommandContext ctx) protected Iterable<OIdentifiable>OFieldMatchPathItem.traversePatternEdge(OMatchStatement.MatchContext matchContext, OIdentifiable startingPoint, OCommandContext iCommandContext) protected Iterable<OIdentifiable>OMatchPathItem.traversePatternEdge(OMatchStatement.MatchContext matchContext, OIdentifiable startingPoint, OCommandContext iCommandContext) protected Iterable<OIdentifiable>OMatchPathItemFirst.traversePatternEdge(OMatchStatement.MatchContext matchContext, OIdentifiable startingPoint, OCommandContext iCommandContext) protected Iterable<OIdentifiable>OMultiMatchPathItem.traversePatternEdge(OMatchStatement.MatchContext matchContext, OIdentifiable startingPoint, OCommandContext iCommandContext) Constructors in com.orientechnologies.orient.core.sql.parser with parameters of type OCommandContextModifierConstructorDescriptionWhileStep(OBooleanExpression condition, List<OStatement> statements, OCommandContext ctx, boolean enableProfiling) -
Uses of OCommandContext in com.orientechnologies.orient.etl
Fields in com.orientechnologies.orient.etl declared as OCommandContextModifier and TypeFieldDescriptionprotected OCommandContextOETLAbstractComponent.contextprotected final OCommandContextOETLPipeline.contextMethods in com.orientechnologies.orient.etl that return OCommandContextMethods in com.orientechnologies.orient.etl with parameters of type OCommandContextModifier and TypeMethodDescriptionprotected voidOETLProcessor.configRunBehaviour(OCommandContext context) voidOETLAbstractComponent.configure(ODocument iConfiguration, OCommandContext iContext) voidOETLComponent.configure(ODocument configuration, OCommandContext context) Called by the @OETLProcessorOETLProcessorConfigurator.configureBeginBlocks(ODocument cfg, OCommandContext iContext) protected <C extends OETLComponent>
COETLProcessorConfigurator.configureComponent(C iComponent, ODocument iCfg, OCommandContext iContext) OETLProcessorConfigurator.configureEndBlocks(ODocument cfg, OCommandContext iContext) protected OETLExtractorOETLProcessorConfigurator.configureExtractor(ODocument cfg, OCommandContext iContext) protected OETLLoaderOETLProcessorConfigurator.configureLoader(ODocument cfg, OCommandContext iContext) protected OETLSourceOETLProcessorConfigurator.configureSource(ODocument cfg, OCommandContext iContext) protected List<OETLTransformer>OETLProcessorConfigurator.configureTransformers(ODocument cfg, OCommandContext iContext) voidOETLAbstractPipelineComponent.setContext(OCommandContext context) voidOETLPipelineComponent.setContext(OCommandContext context) -
Uses of OCommandContext in com.orientechnologies.orient.etl.block
Methods in com.orientechnologies.orient.etl.block with parameters of type OCommandContextModifier and TypeMethodDescriptionvoidOETLCodeBlock.configure(ODocument iConfiguration, OCommandContext iContext) voidOETLConsoleBlock.configure(ODocument iConfiguration, OCommandContext iContext) voidOETLLetBlock.configure(ODocument iConfiguration, OCommandContext iContext) voidOETLAbstractBlock.setContext(OCommandContext iContext) voidOETLBlock.setContext(OCommandContext context) -
Uses of OCommandContext in com.orientechnologies.orient.etl.context
Classes in com.orientechnologies.orient.etl.context that implement OCommandContextModifier and TypeClassDescriptionclassOETLContext extends OBasicCommandContext, in order to handle the following additional elements: - message handler for application messagesMethods in com.orientechnologies.orient.etl.context that return OCommandContextMethods in com.orientechnologies.orient.etl.context with parameters of type OCommandContext -
Uses of OCommandContext in com.orientechnologies.orient.etl.extractor
Methods in com.orientechnologies.orient.etl.extractor with parameters of type OCommandContextModifier and TypeMethodDescriptionvoidOETLCSVExtractor.configure(ODocument iConfiguration, OCommandContext iContext) voidOETLJDBCExtractor.configure(ODocument iConfiguration, OCommandContext iContext) voidOETLRowExtractor.configure(ODocument iConfiguration, OCommandContext iContext) voidOETLXmlExtractor.configure(ODocument iConfiguration, OCommandContext iContext) -
Uses of OCommandContext in com.orientechnologies.orient.etl.listener
Methods in com.orientechnologies.orient.etl.listener with parameters of type OCommandContextModifier and TypeMethodDescriptionvoidOETLDefaultImporterListener.onAfterFile(ODatabaseDocument db, OCommandContext iContext) voidOETLImporterListener.onAfterFile(ODatabaseDocument db, OCommandContext iContext) voidOETLScriptImporterListener.onAfterFile(ODatabaseDocument db, OCommandContext iContext) voidOETLDefaultImporterListener.onAfterLine(ODatabaseDocument db, OCommandContext iContext) voidOETLImporterListener.onAfterLine(ODatabaseDocument db, OCommandContext iContext) voidOETLScriptImporterListener.onAfterLine(ODatabaseDocument db, OCommandContext iContext) voidOETLDefaultImporterListener.onBeforeFile(ODatabaseDocument db, OCommandContext iContext) voidOETLImporterListener.onBeforeFile(ODatabaseDocument db, OCommandContext iContext) voidOETLScriptImporterListener.onBeforeFile(ODatabaseDocument db, OCommandContext iContext) booleanOETLDefaultImporterListener.onBeforeLine(ODatabaseDocument db, OCommandContext iContext) booleanOETLImporterListener.onBeforeLine(ODatabaseDocument db, OCommandContext iContext) booleanOETLScriptImporterListener.onBeforeLine(ODatabaseDocument db, OCommandContext iContext) voidOETLDefaultImporterListener.onDump(ODatabaseDocument db, OCommandContext iContext) voidOETLImporterListener.onDump(ODatabaseDocument db, OCommandContext iContext) voidOETLScriptImporterListener.onDump(ODatabaseDocument db, OCommandContext iContext) voidOETLDefaultImporterListener.onJoinNotFound(ODatabaseDocument db, OCommandContext iContext, OIndex iIndex, Object iKey) voidOETLImporterListener.onJoinNotFound(ODatabaseDocument db, OCommandContext iContext, OIndex iIndex, Object iKey) voidOETLScriptImporterListener.onJoinNotFound(ODatabaseDocument db, OCommandContext iContext, OIndex iIndex, Object iKey) voidOETLDefaultImporterListener.validate(ODatabaseDocument db, OCommandContext iContext, ODocument iRecord) voidOETLImporterListener.validate(ODatabaseDocument db, OCommandContext iContext, ODocument iRecord) voidOETLScriptImporterListener.validate(ODatabaseDocument db, OCommandContext iContext, ODocument iRecord) -
Uses of OCommandContext in com.orientechnologies.orient.etl.loader
Methods in com.orientechnologies.orient.etl.loader with parameters of type OCommandContextModifier and TypeMethodDescriptionvoidOETLOrientDBLoader.configure(ODocument conf, OCommandContext iContext) voidOETLLoader.load(ODatabaseDocument db, Object input, OCommandContext context) voidOETLOrientDBLoader.load(ODatabaseDocument db, Object input, OCommandContext context) voidOETLOutputLoader.load(ODatabaseDocument db, Object input, OCommandContext context) -
Uses of OCommandContext in com.orientechnologies.orient.etl.source
Methods in com.orientechnologies.orient.etl.source with parameters of type OCommandContextModifier and TypeMethodDescriptionvoidOETLContentSource.configure(ODocument iConfiguration, OCommandContext iContext) voidOETLFileSource.configure(ODocument iConfiguration, OCommandContext iContext) voidOETLHttpSource.configure(ODocument iConfiguration, OCommandContext iContext) -
Uses of OCommandContext in com.orientechnologies.orient.etl.transformer
Methods in com.orientechnologies.orient.etl.transformer with parameters of type OCommandContextModifier and TypeMethodDescriptionvoidOETLAbstractLookupTransformer.configure(ODocument iConfiguration, OCommandContext iContext) voidOETLBlockTransformer.configure(ODocument iConfiguration, OCommandContext iContext) voidOETLCodeTransformer.configure(ODocument iConfiguration, OCommandContext iContext) voidOETLCommandTransformer.configure(ODocument conf, OCommandContext ctx) voidOETLEdgeTransformer.configure(ODocument iConfiguration, OCommandContext iContext) voidOETLFieldTransformer.configure(ODocument iConfiguration, OCommandContext iContext) voidOETLFlowTransformer.configure(ODocument iConfiguration, OCommandContext iContext) voidOETLLinkTransformer.configure(ODocument iConfiguration, OCommandContext iContext) voidOETLLogTransformer.configure(ODocument iConfiguration, OCommandContext iContext) voidOETLVertexTransformer.configure(ODocument iConfiguration, OCommandContext iContext) voidOETLBlockTransformer.setContext(OCommandContext context) -
Uses of OCommandContext in com.orientechnologies.orient.graph.sql.functions
Fields in com.orientechnologies.orient.graph.sql.functions declared as OCommandContextModifier and TypeFieldDescriptionprotected OCommandContextOSQLFunctionHeuristicPathFinderAbstract.contextprotected OCommandContextOSQLFunctionPathFinder.contextMethods in com.orientechnologies.orient.graph.sql.functions with parameters of type OCommandContextModifier and TypeMethodDescriptionOSQLFunctionAstar.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) Deprecated.OSQLFunctionDijkstra.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) Deprecated.OSQLFunctionGremlin.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLFunctionLabel.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParameters, OCommandContext iContext) protected LinkedList<OrientVertex>OSQLFunctionPathFinder.execute(OCommandContext iContext) OSQLFunctionShortestPath.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) Deprecated. -
Uses of OCommandContext in com.orientechnologies.orient.object.db
Methods in com.orientechnologies.orient.object.db that return OCommandContextMethods in com.orientechnologies.orient.object.db with parameters of type OCommandContext -
Uses of OCommandContext in com.orientechnologies.spatial.functions
Methods in com.orientechnologies.spatial.functions with parameters of type OCommandContextModifier and TypeMethodDescriptionbooleanOSpatialFunctionAbstractIndexable.allowsIndexedExecution(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) booleanOSpatialFunctionAbstractIndexable.canExecuteInline(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) longOSpatialFunctionAbstractIndexable.estimate(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) longOSTDistanceSphereFunction.estimate(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) OSTAsBinaryFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSTAsGeoJSONFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSTAsTextFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSTBufferFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSTContainsFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSTDisjointFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSTDistanceFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSTDistanceSphereFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSTDWithinFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSTEnvelopFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSTEqualsFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSTGeomFromGeoJSONFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSTGeomFromTextFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSTIntersectsFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSTSrid.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSTWithinFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) protected voidOSpatialFunctionAbstractIndexable.onAfterParsing(Map<String, Object> params, OExpression[] args, OCommandContext ctx, Object rightValue) protected voidOSTDistanceSphereFunction.onAfterParsing(Map<String, Object> params, OExpression[] args, OCommandContext ctx, Object rightValue) protected voidOSTDWithinFunction.onAfterParsing(Map<String, Object> params, OExpression[] args, OCommandContext ctx, Object rightValue) protected Iterable<OIdentifiable>OSpatialFunctionAbstractIndexable.results(OFromClause target, OExpression[] args, OCommandContext ctx, Object rightValue) OSTContainsFunction.searchFromTarget(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) OSTDistanceSphereFunction.searchFromTarget(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) OSTDWithinFunction.searchFromTarget(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) OSTIntersectsFunction.searchFromTarget(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) OSTWithinFunction.searchFromTarget(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) booleanOSpatialFunctionAbstractIndexable.shouldExecuteAfterSearch(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) -
Uses of OCommandContext in com.orientechnologies.spatial.operator
Methods in com.orientechnologies.spatial.operator with parameters of type OCommandContextModifier and TypeMethodDescriptionOLuceneNearOperator.evaluateRecord(OIdentifiable iRecord, ODocument iCurrentResult, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext, ODocumentSerializer serializer) OLuceneOverlapOperator.evaluateRecord(OIdentifiable iRecord, ODocument iCurrentResult, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext, ODocumentSerializer serializer) OLuceneSpatialOperator.evaluateRecord(OIdentifiable iRecord, ODocument iCurrentResult, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext, ODocumentSerializer serializer) OLuceneWithinOperator.evaluateRecord(OIdentifiable iRecord, ODocument iCurrentResult, OSQLFilterCondition iCondition, Object iLeft, Object iRight, OCommandContext iContext, ODocumentSerializer serializer) OLuceneNearOperator.executeIndexQuery(OCommandContext iContext, OIndex index, List<Object> keyParams, boolean ascSortOrder) OLuceneOverlapOperator.executeIndexQuery(OCommandContext iContext, OIndex index, List<Object> keyParams, boolean ascSortOrder) OLuceneWithinOperator.executeIndexQuery(OCommandContext iContext, OIndex index, List<Object> keyParams, boolean ascSortOrder) OLuceneNearOperator.getOIndexSearchResult(OClass iSchemaClass, OSQLFilterCondition iCondition, List<OIndexSearchResult> iIndexSearchResults, OCommandContext context) OLuceneSpatialOperator.getOIndexSearchResult(OClass iSchemaClass, OSQLFilterCondition iCondition, List<OIndexSearchResult> iIndexSearchResults, OCommandContext context) OLuceneWithinOperator.getOIndexSearchResult(OClass iSchemaClass, OSQLFilterCondition iCondition, List<OIndexSearchResult> iIndexSearchResults, OCommandContext context) -
Uses of OCommandContext in com.orientechnologies.spatial.query
Constructors in com.orientechnologies.spatial.query with parameters of type OCommandContextModifierConstructorDescriptionOSpatialQueryContext(OCommandContext context, org.apache.lucene.search.IndexSearcher searcher, org.apache.lucene.search.Query query) OSpatialQueryContext(OCommandContext context, org.apache.lucene.search.IndexSearcher searcher, org.apache.lucene.search.Query query, List<org.apache.lucene.search.SortField> sortFields) -
Uses of OCommandContext in com.tinkerpop.blueprints.impls.orient
Methods in com.tinkerpop.blueprints.impls.orient that return OCommandContextMethods in com.tinkerpop.blueprints.impls.orient with parameters of type OCommandContext