Uses of Interface
com.orientechnologies.orient.core.command.OCommandContext
Packages that use OCommandContext
Package
Description
-
Uses of OCommandContext in com.orientechnologies.agent.functions
Methods in com.orientechnologies.agent.functions with parameters of type OCommandContextModifier and TypeMethodDescriptionKillQueryFunction.exec(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) KillSessionFunction.exec(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) ListQueriesFunction.exec(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) ListSessionsFunction.exec(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) abstract ObjectOSQLEnterpriseFunction.exec(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) OSQLEnterpriseFunction.execute(Object iThis, OIdentifiable iCurrentRecord, Object iCurrentResult, Object[] iParams, OCommandContext iContext) protected booleanOSQLEnterpriseFunction.sameDatabase(OClientConnection connection, OCommandContext iContext) -
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 TypeMethodDescriptionbooleanOLuceneCrossClassSearchFunction.allowsIndexedExecution(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) booleanOLuceneSearchFunctionTemplate.allowsIndexedExecution(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) booleanOLuceneSearchMoreLikeThisFunction.allowsIndexedExecution(OFromClause target, OBinaryCompareOperator operator, Object rightValue, OCommandContext ctx, OExpression... args) booleanOLuceneCrossClassSearchFunction.canExecuteInline(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) longOLuceneCrossClassSearchFunction.estimate(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) OLuceneCrossClassSearchFunction.execute(Object iThis, OIdentifiable currentRecord, Object currentResult, Object[] params, OCommandContext ctx) 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) OLuceneSearchOnIndexFunction.getResult(OCommandContext ctx) protected OLuceneFullTextIndexOLuceneCrossClassSearchFunction.searchForIndex(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) OLuceneCrossClassSearchFunction.searchFromTarget(OFromClause target, OBinaryCompareOperator operator, Object rightValue, 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) booleanOLuceneCrossClassSearchFunction.shouldExecuteAfterSearch(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.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 OCommandContextOBasicCommandContext.parentMethods in com.orientechnologies.orient.core.command that return OCommandContextModifier and TypeMethodDescriptionOBasicCommandContext.copy()OCommandContext.copy()Creates a copy of execution context.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 TypeMethodDescriptionOScriptExecutor.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) 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 TypeMethodDescriptionOAbstractScriptExecutor.bind(Bindings binding, ODatabaseDocumentInternal db, OCommandContext iContext, Map<Object, Object> iArgs, OScriptManager scriptManager) OAbstractScriptExecutor.bindContextVariables(Bindings binding, ODatabaseDocumentInternal db, OCommandContext iContext, Map<Object, Object> iArgs, OScriptManager scriptManager) voidOAbstractScriptExecutor.unbind(Bindings binding, OCommandContext iContext, Map<Object, Object> iArgs, OScriptManager scriptManager) Unbinds variables -
Uses of OCommandContext in com.orientechnologies.orient.core.command.script.nashorn
Methods in com.orientechnologies.orient.core.command.script.nashorn with parameters of type OCommandContextModifier and TypeMethodDescriptionONashornScriptExecutor.executeFunction(OCommandContext context, String functionName, Map<Object, Object> iArgs) -
Uses of OCommandContext in com.orientechnologies.orient.core.command.script.polyglot
Methods in com.orientechnologies.orient.core.command.script.polyglot with parameters of type OCommandContextModifier and TypeMethodDescriptionOPolyglotScriptExecutor.executeFunction(OCommandContext context, String functionName, Map<Object, Object> iArgs) -
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.ODatabaseFunction.getResult(OCommandContext ctx) -
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 context) Evaluates a SQL expression against current document by passing a context.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
Methods in com.orientechnologies.orient.core.sql with parameters of type OCommandContextModifier and TypeMethodDescriptionstatic ObjectOSQLEngine.eval(String expression, Object target, OCommandContext ctx) static ObjectOSQLEngine.foreachRecord(OCallable<Object, OIdentifiable> iCallable, Object iCurrent, OCommandContext iContext) static ObjectOSQLHelper.getValue(Object iObject, ORecord iRecord, OCommandContext iContext) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.executor
Methods in com.orientechnologies.orient.core.sql.executor that return OCommandContextModifier and TypeMethodDescriptionOToResultContext.getContext()OToResultContextImpl.getContext()Methods in com.orientechnologies.orient.core.sql.executor with parameters of type OCommandContextModifier and TypeMethodDescriptionvoidAggregationContext.apply(OResult next, OCommandContext ctx) voidOFunctionAggregationContext.apply(OResult next, 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 OExecutionStepInternalOExecutionStepInternal.copy(OCommandContext ctx) OInsertExecutionPlan.copy(OCommandContext ctx) default OInternalExecutionPlanOInternalExecutionPlan.copy(OCommandContext ctx) OSelectExecutionPlan.copy(OCommandContext ctx) default OServerExecutionPlanOServerExecutionPlan.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) OCreateEdgeExecutionPlanner.createExecutionPlan(OCommandContext ctx, boolean useCache) OCreateVertexExecutionPlanner.createExecutionPlan(OCommandContext ctx) ODeleteEdgeExecutionPlanner.createExecutionPlan(OCommandContext ctx, boolean useCache) ODeleteExecutionPlanner.createExecutionPlan(OCommandContext ctx) ODeleteVertexExecutionPlanner.createExecutionPlan(OCommandContext ctx) OFindReferencesExecutionPlanner.createExecutionPlan(OCommandContext ctx) OInsertExecutionPlanner.createExecutionPlan(OCommandContext ctx) OMatchExecutionPlanner.createExecutionPlan(OCommandContext context) OMoveVertexExecutionPlanner.createExecutionPlan(OCommandContext ctx) OSelectExecutionPlanner.createExecutionPlan(OCommandContext ctx, boolean useCache) OTraverseExecutionPlanner.createExecutionPlan(OCommandContext ctx) OUpdateExecutionPlanner.createExecutionPlan(OCommandContext ctx) MatchStep.createNextResultSet(OResult lastUpstreamRecord, OCommandContext ctx) protected OExecutionStreamMatchEdgeTraverser.executeTraversal(OCommandContext iCommandContext, OMatchPathItem item, Object startingPoint, int depth, List<OIdentifiable> pathToHere) PatternEdge.executeTraversal(OMatchStatement.MatchContext matchContext, OCommandContext iCommandContext, OIdentifiable startingPoint, int depth) protected abstract voidAbstractTraverseStep.fetchNextEntryPoints(OExecutionStream toFetch, OCommandContext ctx, List<OResult> entryPoints, Set<ORID> traversed) protected voidBreadthFirstTraverseStep.fetchNextEntryPoints(OExecutionStream nextN, OCommandContext ctx, List<OResult> entryPoints, Set<ORID> traversed) protected voidDepthFirstTraverseStep.fetchNextEntryPoints(OExecutionStream nextN, OCommandContext ctx, List<OResult> entryPoints, Set<ORID> traversed) protected abstract voidAbstractTraverseStep.fetchNextResults(OCommandContext ctx, List<OResult> results, List<OResult> entryPoints, Set<ORID> traversed) protected voidBreadthFirstTraverseStep.fetchNextResults(OCommandContext ctx, List<OResult> results, List<OResult> entryPoints, Set<ORID> traversed) protected voidDepthFirstTraverseStep.fetchNextResults(OCommandContext ctx, List<OResult> results, List<OResult> entryPoints, Set<ORID> traversed) AggregationContext.getFinalValue(OCommandContext ctx) OFunctionAggregationContext.getFinalValue(OCommandContext ctx) static voidOSelectExecutionPlanner.handleOrderBy(OSelectExecutionPlan plan, QueryPlanningInfo info, OCommandContext ctx) static voidOSelectExecutionPlanner.handleProjectionsBlock(OSelectExecutionPlan result, QueryPlanningInfo info, OCommandContext ctx) booleanMatchEdgeTraverser.hasNext(OCommandContext ctx) ForEachStep.init(OCommandContext ctx) protected voidMatchEdgeTraverser.init(OCommandContext ctx) protected voidOptionalMatchEdgeTraverser.init(OCommandContext ctx) IfStep.initNegativePlan(OCommandContext ctx) ForEachStep.initPlan(OCommandContext ctx) RetryStep.initPlan(List<OStatement> body, OCommandContext ctx) IfStep.initPositivePlan(OCommandContext ctx) protected abstract OExecutionStreamAbstractExecutionStep.internalStart(OCommandContext ctx) AbstractTraverseStep.internalStart(OCommandContext ctx) AbstractUnrollStep.internalStart(OCommandContext ctx) AccumulatingTimeoutStep.internalStart(OCommandContext ctx) AggregateProjectionCalculationStep.internalStart(OCommandContext ctx) BatchStep.internalStart(OCommandContext ctx) CartesianProductStep.internalStart(OCommandContext ctx) CastToEdgeStep.internalStart(OCommandContext ctx) CastToVertexStep.internalStart(OCommandContext ctx) CheckClassTypeStep.internalStart(OCommandContext context) CheckClusterTypeStep.internalStart(OCommandContext context) CheckRecordTypeStep.internalStart(OCommandContext ctx) CheckSafeDeleteStep.internalStart(OCommandContext ctx) ConvertToResultInternalStep.internalStart(OCommandContext ctx) ConvertToUpdatableResultStep.internalStart(OCommandContext ctx) CopyDocumentStep.internalStart(OCommandContext ctx) CopyRecordContentBeforeUpdateStep.internalStart(OCommandContext ctx) CountFromClassStep.internalStart(OCommandContext ctx) CountFromIndexStep.internalStart(OCommandContext ctx) CountFromIndexWithKeyStep.internalStart(OCommandContext ctx) CountStep.internalStart(OCommandContext ctx) CreateEdgesStep.internalStart(OCommandContext ctx) CreateRecordStep.internalStart(OCommandContext ctx) DeleteFromIndexStep.internalStart(OCommandContext ctx) DeleteStep.internalStart(OCommandContext ctx) DistinctExecutionStep.internalStart(OCommandContext ctx) DistributedExecutionStep.internalStart(OCommandContext ctx) EmptyDataGeneratorStep.internalStart(OCommandContext ctx) EmptyStep.internalStart(OCommandContext ctx) ExpandStep.internalStart(OCommandContext ctx) FetchEdgesFromToVerticesStep.internalStart(OCommandContext ctx) FetchEdgesToVerticesStep.internalStart(OCommandContext ctx) FetchFromClassExecutionStep.internalStart(OCommandContext ctx) FetchFromClusterExecutionStep.internalStart(OCommandContext ctx) FetchFromClustersExecutionStep.internalStart(OCommandContext ctx) FetchFromDatabaseMetadataStep.internalStart(OCommandContext ctx) FetchFromDistributedMetadataStep.internalStart(OCommandContext ctx) FetchFromIndexedFunctionStep.internalStart(OCommandContext ctx) FetchFromIndexStep.internalStart(OCommandContext ctx) FetchFromRidsStep.internalStart(OCommandContext ctx) FetchFromStorageMetadataStep.internalStart(OCommandContext ctx) FetchFromVariableStep.internalStart(OCommandContext ctx) FetchTemporaryFromTxStep.internalStart(OCommandContext ctx) FilterByClassStep.internalStart(OCommandContext ctx) FilterByClustersStep.internalStart(OCommandContext ctx) FilterNotMatchPatternStep.internalStart(OCommandContext ctx) FilterStep.internalStart(OCommandContext ctx) FindReferencesStep.internalStart(OCommandContext ctx) ForEachStep.internalStart(OCommandContext ctx) GetValueFromIndexEntryStep.internalStart(OCommandContext ctx) GlobalLetExpressionStep.internalStart(OCommandContext ctx) GlobalLetQueryStep.internalStart(OCommandContext ctx) GuaranteeEmptyCountStep.internalStart(OCommandContext ctx) IfStep.internalStart(OCommandContext ctx) InsertIntoIndexStep.internalStart(OCommandContext ctx) InsertValuesStep.internalStart(OCommandContext ctx) LetExpressionStep.internalStart(OCommandContext ctx) LetQueryStep.internalStart(OCommandContext ctx) LimitExecutionStep.internalStart(OCommandContext ctx) LockRecordStep.internalStart(OCommandContext ctx) MatchFirstStep.internalStart(OCommandContext ctx) MatchPrefetchStep.internalStart(OCommandContext ctx) MatchStep.internalStart(OCommandContext ctx) MoveVertexStep.internalStart(OCommandContext ctx) OrderByStep.internalStart(OCommandContext ctx) ParallelExecStep.internalStart(OCommandContext ctx) ProjectionCalculationStep.internalStart(OCommandContext ctx) RemoveEdgePointersStep.internalStart(OCommandContext ctx) RemoveEmptyOptionalsStep.internalStart(OCommandContext ctx) RetryStep.internalStart(OCommandContext ctx) ReturnMatchPathsStep.internalStart(OCommandContext ctx) ReturnMatchPatternsStep.internalStart(OCommandContext ctx) ReturnStep.internalStart(OCommandContext ctx) SaveElementStep.internalStart(OCommandContext ctx) ScriptLineStep.internalStart(OCommandContext ctx) SetDocumentClassStep.internalStart(OCommandContext ctx) SkipExecutionStep.internalStart(OCommandContext ctx) SubQueryStep.internalStart(OCommandContext ctx) TimeoutStep.internalStart(OCommandContext ctx) UnlockRecordStep.internalStart(OCommandContext ctx) UnwindStep.internalStart(OCommandContext ctx) UnwrapPreviousValueStep.internalStart(OCommandContext ctx) UpdateContentStep.internalStart(OCommandContext ctx) UpdateEdgePointersStep.internalStart(OCommandContext ctx) UpdateMergeStep.internalStart(OCommandContext ctx) UpdateRemoveStep.internalStart(OCommandContext ctx) UpdateSetStep.internalStart(OCommandContext ctx) UpsertStep.internalStart(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) IfStep.producePlan(OCommandContext ctx) voidOServerExecutionPlan.reset(OCommandContext ctx) voidOSingleOpServerExecutionPlan.reset(OCommandContext ctx) AbstractExecutionStep.start(OCommandContext ctx) OAllIndexStream.start(OCommandContext ctx) OBetweenIndexStream.start(OCommandContext ctx) ODDLExecutionPlan.start(OCommandContext ctx) OExactIndexStream.start(OCommandContext ctx) OExecutionStepInternal.start(OCommandContext ctx) OIfExecutionPlan.start(OCommandContext ctx) OIndexStream.start(OCommandContext ctx) OInsertExecutionPlan.start(OCommandContext ctx) OInternalExecutionPlan.start(OCommandContext ctx) if the execution can still return N elements, then the result will contain them all.OMajorIndexStream.start(OCommandContext ctx) OMinorIndexStream.start(OCommandContext ctx) ONullIndexStream.start(OCommandContext ctx) OScriptExecutionPlan.start(OCommandContext ctx) OSelectExecutionPlan.start(OCommandContext ctx) OSingleOpExecutionPlan.start(OCommandContext ctx) OUpdateExecutionPlan.start(OCommandContext ctx) 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 OExecutionStreamMatchEdgeTraverser.traversePatternEdge(OIdentifiable startingPoint, OCommandContext iCommandContext) protected OExecutionStreamMatchFieldTraverser.traversePatternEdge(OIdentifiable startingPoint, OCommandContext iCommandContext) protected OExecutionStreamMatchMultiEdgeTraverser.traversePatternEdge(OIdentifiable startingPoint, OCommandContext iCommandContext) protected OExecutionStreamMatchReverseEdgeTraverser.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 OCommandContextModifierConstructorDescriptionBatchStep(OBatch batch, OCommandContext ctx) FetchFromClassExecutionStep(String className, Set<String> clusters, OCommandContext ctx, Boolean ridOrder) FetchFromClassExecutionStep(String className, Set<String> clusters, QueryPlanningInfo planningInfo, OCommandContext ctx, Boolean ridOrder) iterates over a class and its subclassesFetchFromIndexStep(OIndexCandidate candidate, boolean orderAsc, OCommandContext ctx) FetchFromIndexValuesStep(OIndexCandidate desc, boolean orderAsc, OCommandContext ctx) FetchFromViewExecutionStep(String className, Set<String> clusters, QueryPlanningInfo planningInfo, OCommandContext ctx, Boolean ridOrder) GlobalLetQueryStep(OIdentifier varName, OStatement query, OCommandContext ctx, List<String> scriptVars) MatchFirstStep(OCommandContext context, PatternNode node) MoveVertexStep(OIdentifier targetClass, OCluster targetCluster, OCommandContext ctx) OPrintContexImpl(OCommandContext ctx, int depth, int ident) OToResultContextImpl(OCommandContext context) ReturnMatchElementsStep(OCommandContext context) SubQueryStep(OInternalExecutionPlan subExecutionPlan, OCommandContext ctx, OCommandContext subCtx) executes a sub-queryWhileMatchStep(OCommandContext ctx, OWhereClause condition, OInternalExecutionPlan body) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.executor.metadata
Methods in com.orientechnologies.orient.core.sql.executor.metadata with parameters of type OCommandContextModifier and TypeMethodDescriptionlongOIndexCanditateAny.cost(OIndexCandidate candidate, OCommandContext ctx) default Optional<OIndexCandidate>OIndexCandidate.finalize(OCommandContext ctx) OIndexCandidateOne.finalize(OCommandContext ctx) OIndexCanditateAny.finalize(OCommandContext ctx) OClassIndexFinder.findAllowRange(OPath path, OIndexFinder.Operation op, OIndexKeySource value, OCommandContext ctx) OIndexFinder.findAllowRange(OPath fieldName, OIndexFinder.Operation operation, OIndexKeySource value, OCommandContext ctx) OSpecificIndexFinder.findAllowRange(OPath fieldName, OIndexFinder.Operation operation, OIndexKeySource value, OCommandContext ctx) OClassIndexFinder.findAny(OPath path, OIndexKeySource value, OCommandContext ctx) OIndexFinder.findAny(OPath oPath, OIndexKeySource value, OCommandContext ctx) OSpecificIndexFinder.findAny(OPath oPath, OIndexKeySource value, OCommandContext ctx) OClassIndexFinder.findByKey(OPath path, OIndexKeySource value, OCommandContext ctx) OIndexFinder.findByKey(OPath fieldName, OIndexKeySource value, OCommandContext ctx) OSpecificIndexFinder.findByKey(OPath fieldName, OIndexKeySource value, OCommandContext ctx) OClassIndexFinder.findByValue(OPath path, OIndexKeySource value, OCommandContext ctx) OIndexFinder.findByValue(OPath fieldName, OIndexKeySource value, OCommandContext ctx) OSpecificIndexFinder.findByValue(OPath fieldName, OIndexKeySource value, OCommandContext ctx) protected OClassOClassIndexFinder.findClass(OCommandContext ctx) OClassIndexFinder.findExact(OPath path, OIndexKeySource value, OCommandContext ctx) OClassIndexFinder.findExact(OPath path, OIndexKeySource value, OCommandContext ctx, boolean requireDistinct) OIndexFinder.findExact(OPath fieldName, OIndexKeySource value, OCommandContext ctx) OSpecificIndexFinder.findExact(OPath fieldName, OIndexKeySource value, OCommandContext ctx) OClassIndexFinder.findFullText(OPath path, OIndexKeySource value, OCommandContext ctx) OIndexFinder.findFullText(OPath fieldName, OIndexKeySource value, OCommandContext ctx) OSpecificIndexFinder.findFullText(OPath fieldName, OIndexKeySource value, OCommandContext ctx) OClassIndexFinder.findNull(OPath path, OCommandContext ctx) OIndexFinder.findNull(OPath fieldName, OCommandContext ctx) OSpecificIndexFinder.findNull(OPath fieldName, OCommandContext ctx) OClassIndexFinder.findRange(OPath path, OIndexKeySource first, OIndexKeySource second, OCommandContext ctx) OIndexFinder.findRange(OPath fieldName, OIndexKeySource first, OIndexKeySource second, OCommandContext ctx) OSpecificIndexFinder.findRange(OPath fieldName, OIndexKeySource first, OIndexKeySource second, OCommandContext ctx) booleanOIndexCandidate.fullySorted(List<String> properties, OCommandContext ctx) booleanOIndexCandidateChain.fullySorted(List<String> properties, OCommandContext ctx) booleanOIndexCandidateOne.fullySorted(List<String> orderItems, OCommandContext ctx) booleanOIndexCanditateAll.fullySorted(List<String> properties, OCommandContext ctx) booleanOIndexCanditateAny.fullySorted(List<String> orderItems, OCommandContext ctx) default List<OIndexStream>OIndexCandidate.getStreams(OCommandContext ctx, boolean isOrderAsc) OIndexCandidateOne.getStreams(OCommandContext ctx, boolean isOrderAsc) OIndexCanditateAll.getStreams(OCommandContext ctx, boolean isOrderAsc) OIndexCanditateAny.getStreams(OCommandContext ctx, boolean isOrderAsc) OIndexKeySource.key(OCommandContext ctx, boolean asc) OIndexCandidate.normalize(OCommandContext ctx) OIndexCandidateChain.normalize(OCommandContext ctx) OIndexCandidateOne.normalize(OCommandContext ctx) OIndexCanditateAll.normalize(OCommandContext ctx) OIndexCanditateAny.normalize(OCommandContext ctx) booleanOIndexCandidate.requiresDistinctStep(OCommandContext ctx) booleanOIndexCandidateChain.requiresDistinctStep(OCommandContext ctx) booleanOIndexCandidateOne.requiresDistinctStep(OCommandContext ctx) booleanOIndexCanditateAll.requiresDistinctStep(OCommandContext ctx) booleanOIndexCanditateAny.requiresDistinctStep(OCommandContext ctx) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.executor.resultset
Constructors in com.orientechnologies.orient.core.sql.executor.resultset with parameters of type OCommandContextModifierConstructorDescriptionOExecutionResultSet(OExecutionStream stream, OCommandContext context, OInternalExecutionPlan plan) OServerResultSet(OExecutionStream stream, OCommandContext context, OExecutionPlanContextOps plan) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.executor.stream
Methods in com.orientechnologies.orient.core.sql.executor.stream with parameters of type OCommandContextModifier and TypeMethodDescriptionvoidOCostMeasureExecutionStream.close(OCommandContext ctx) voidOEdgeTraverserExcutionStream.close(OCommandContext ctx) voidOEmptyExecutionStream.close(OCommandContext ctx) voidOExcutionStreamProducerFromIterator.close(OCommandContext ctx) voidOExecutionStream.close(OCommandContext ctx) voidOExecutionStream.OnClose.close(OCommandContext ctx) voidOExecutionStreamProducer.close(OCommandContext ctx) voidOFilterExecutionStream.close(OCommandContext ctx) voidOFlatMapExecutionStream.close(OCommandContext ctx) voidOInterruptExecutionStream.close(OCommandContext ctx) voidOIteratorExecutionStream.close(OCommandContext ctx) voidOLimitedExecutionStream.close(OCommandContext ctx) voidOLoaderExecutionStream.close(OCommandContext ctx) voidOMapExecutionStream.close(OCommandContext ctx) voidOMultipleExecutionStream.close(OCommandContext ctx) voidOnCloseExecutionStream.close(OCommandContext ctx) voidOProduceExecutionStream.close(OCommandContext ctx) voidOResultCollectionExecutionStream.close(OCommandContext ctx) voidOResultIteratorExecutionStream.close(OCommandContext ctx) voidOSingletonExecutionStream.close(OCommandContext ctx) voidOTerminationExecutionStream.close(OCommandContext ctx) voidOTimeoutExecutionStream.close(OCommandContext ctx) static OExecutionStreamOExecutionStream.collectAll(OExecutionStream from, OCommandContext ctx) static voidOExecutionStream.consume(OExecutionStream toConsume, OCommandContext ctx) OFilterResult.filterMap(OResult result, OCommandContext ctx) Filter and change a resultOFlatMapResult.flatMap(OResult next, OCommandContext ctx) booleanOCostMeasureExecutionStream.hasNext(OCommandContext ctx) booleanOEdgeTraverserExcutionStream.hasNext(OCommandContext ctx) booleanOEmptyExecutionStream.hasNext(OCommandContext ctx) booleanOExcutionStreamProducerFromIterator.hasNext(OCommandContext ctx) booleanOExecutionStream.hasNext(OCommandContext ctx) booleanOExecutionStreamProducer.hasNext(OCommandContext ctx) booleanOFilterExecutionStream.hasNext(OCommandContext ctx) booleanOFlatMapExecutionStream.hasNext(OCommandContext ctx) booleanOInterruptExecutionStream.hasNext(OCommandContext ctx) booleanOIteratorExecutionStream.hasNext(OCommandContext ctx) booleanOLimitedExecutionStream.hasNext(OCommandContext ctx) booleanOLoaderExecutionStream.hasNext(OCommandContext ctx) booleanOMapExecutionStream.hasNext(OCommandContext ctx) booleanOMultipleExecutionStream.hasNext(OCommandContext ctx) booleanOnCloseExecutionStream.hasNext(OCommandContext ctx) booleanOProduceExecutionStream.hasNext(OCommandContext ctx) booleanOResultCollectionExecutionStream.hasNext(OCommandContext ctx) booleanOResultIteratorExecutionStream.hasNext(OCommandContext ctx) booleanOSingletonExecutionStream.hasNext(OCommandContext ctx) booleanOTerminationExecutionStream.hasNext(OCommandContext ctx) booleanOTimeoutExecutionStream.hasNext(OCommandContext ctx) booleanOEmptyExecutionStream.isFullInMemory(OCommandContext ctx) default booleanOExecutionStream.isFullInMemory(OCommandContext ctx) Check if the current stream has all the data in memory, without much computation need to get the final result.booleanOInterruptExecutionStream.isFullInMemory(OCommandContext ctx) booleanOLimitedExecutionStream.isFullInMemory(OCommandContext ctx) booleanOnCloseExecutionStream.isFullInMemory(OCommandContext ctx) booleanOResultCollectionExecutionStream.isFullInMemory(OCommandContext ctx) booleanOSingletonExecutionStream.isFullInMemory(OCommandContext ctx) booleanOTerminationExecutionStream.isFullInMemory(OCommandContext ctx) booleanOTimeoutExecutionStream.isFullInMemory(OCommandContext ctx) booleanOCostMeasureExecutionStream.isTermination(OCommandContext ctx) booleanOEdgeTraverserExcutionStream.isTermination(OCommandContext ctx) booleanOEmptyExecutionStream.isTermination(OCommandContext ctx) booleanOExecutionStream.isTermination(OCommandContext ctx) Flag used to terminate scripts early in the execution, used by the return statement via the terminate execution stream The only implementation that tour true isOTerminationExecutionStreamcreated withOExecutionStream.terminate()the other implementation return false if they provide content themselves, or delegate the method if are wrapper (independently of the modifications) of another stream.booleanOFilterExecutionStream.isTermination(OCommandContext ctx) booleanOFlatMapExecutionStream.isTermination(OCommandContext ctx) booleanOInterruptExecutionStream.isTermination(OCommandContext ctx) booleanOIteratorExecutionStream.isTermination(OCommandContext ctx) booleanOLimitedExecutionStream.isTermination(OCommandContext ctx) booleanOLoaderExecutionStream.isTermination(OCommandContext ctx) booleanOMapExecutionStream.isTermination(OCommandContext ctx) booleanOMultipleExecutionStream.isTermination(OCommandContext ctx) booleanOnCloseExecutionStream.isTermination(OCommandContext ctx) booleanOProduceExecutionStream.isTermination(OCommandContext ctx) booleanOResultCollectionExecutionStream.isTermination(OCommandContext ctx) booleanOResultIteratorExecutionStream.isTermination(OCommandContext ctx) booleanOSingletonExecutionStream.isTermination(OCommandContext ctx) booleanOTerminationExecutionStream.isTermination(OCommandContext ctx) booleanOTimeoutExecutionStream.isTermination(OCommandContext ctx) OExecutionStreamProducerValueMap.map(T value, OCommandContext ctx) OMapResult.map(OResult result, OCommandContext ctx) OCostMeasureExecutionStream.next(OCommandContext ctx) OEdgeTraverserExcutionStream.next(OCommandContext ctx) OEmptyExecutionStream.next(OCommandContext ctx) OExcutionStreamProducerFromIterator.next(OCommandContext ctx) OExecutionStream.next(OCommandContext ctx) OExecutionStreamProducer.next(OCommandContext ctx) OFilterExecutionStream.next(OCommandContext ctx) OFlatMapExecutionStream.next(OCommandContext ctx) OInterruptExecutionStream.next(OCommandContext ctx) OIteratorExecutionStream.next(OCommandContext ctx) OLimitedExecutionStream.next(OCommandContext ctx) OLoaderExecutionStream.next(OCommandContext ctx) OMapExecutionStream.next(OCommandContext ctx) OMultipleExecutionStream.next(OCommandContext ctx) OnCloseExecutionStream.next(OCommandContext ctx) OProduceExecutionStream.next(OCommandContext ctx) OResultCollectionExecutionStream.next(OCommandContext ctx) OResultIteratorExecutionStream.next(OCommandContext ctx) OSingletonExecutionStream.next(OCommandContext ctx) OTerminationExecutionStream.next(OCommandContext ctx) OTimeoutExecutionStream.next(OCommandContext ctx) OProduceResult.produce(OCommandContext ctx) OExecutionStream.stream(OCommandContext ctx) -
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. if the index exists on this target and it's defined on these fields)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, OResult current, Object iCurrentResult, Object[] iParams, Iterable<OIdentifiable> iPossibleResults, OCommandContext iContext) Process a record.protected ODatabaseSessionOSQLFunctionAbstract.getDatabase(OCommandContext ctx) protected StringOSQLFunctionAbstract.getDistributedStorageId(OCommandContext ctx) OSQLFunction.getResult(OCommandContext ctx) Only called when function aggregates results after all records have been passed to the function.OSQLFunctionAbstract.getResult(OCommandContext ctx) 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) OSQLFunctionDocument.getResult(OCommandContext ctx) OSQLFunctionIntersect.getResult(OCommandContext ctx) OSQLFunctionList.getResult(OCommandContext ctx) OSQLFunctionMap.getResult(OCommandContext ctx) OSQLFunctionMultiValueAbstract.getResult(OCommandContext ctx) OSQLFunctionSet.getResult(OCommandContext ctx) OSQLFunctionSymmetricDifference.getResult(OCommandContext ctx) OSQLFunctionTraversedElement.getResult(OCommandContext ctx) protected ODocumentOSQLFunctionDocument.prepareResult(ODocument res, OCommandContext ctx) OSQLFunctionList.prepareResult(List<Object> res, OCommandContext iContext) OSQLFunctionMap.prepareResult(Map<Object, Object> res, OCommandContext ctx) OSQLFunctionSet.prepareResult(Set<Object> res, OCommandContext ctx) -
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, OResult current, 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) OSQLFunctionAstar.getResult(OCommandContext ctx) OSQLFunctionPathFinder.getResult(OCommandContext ctx) -
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) OSQLFunctionAbsoluteValue.getResult(OCommandContext ctx) OSQLFunctionAverage.getResult(OCommandContext ctx) OSQLFunctionDecimal.getResult(OCommandContext ctx) OSQLFunctionEval.getResult(OCommandContext ctx) OSQLFunctionInterval.getResult(OCommandContext ctx) OSQLFunctionMax.getResult(OCommandContext ctx) OSQLFunctionMin.getResult(OCommandContext ctx) OSQLFunctionSum.getResult(OCommandContext ctx) -
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) OSQLFunctionCount.getResult(OCommandContext ctx) OSQLFunctionDate.getResult(OCommandContext ctx) OSQLFunctionSysdate.getResult(OCommandContext ctx) OSQLFunctionThrowCME.getResult(OCommandContext ctx) OSQLFunctionUUID.getResult(OCommandContext ctx) -
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) OSQLFunctionSequence.getResult(OCommandContext ctx) -
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) OSQLFunctionMode.getResult(OCommandContext ctx) OSQLFunctionPercentile.getResult(OCommandContext ctx) OSQLFunctionStandardDeviation.getResult(OCommandContext ctx) OSQLFunctionVariance.getResult(OCommandContext ctx) -
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) OSQLFunctionConcat.getResult(OCommandContext ctx) -
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) -
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) 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 TypeMethodDescriptionbooleanOQueryOperator.evaluate(Object iLeft, Object iRight, OCommandContext ctx) -
Uses of OCommandContext in com.orientechnologies.orient.core.sql.parser
Methods 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) voidONodeAllocationData.apply(OClassEmbedded ce, 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.calculateSingle(OCommandContext iContext, OResult iRecord) booleanOBaseExpression.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 indexbooleanOBaseIdentifier.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 indexbooleanOBinaryCondition.canExecuteIndexedFunctionWithoutIndex(OFromClause target, OCommandContext context) tests if current expression involves an indexed function 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 function 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 function 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 ObjectOProjectionItem.convert(Object value, OCommandContext context) static ObjectOUpdateItem.convertToPropertyType(OResultInternal res, OIdentifier attrName, Object newValue, OCommandContext ctx) OCreateEdgeStatement.createExecutionPlan(OCommandContext ctx) OCreateVertexStatement.createExecutionPlan(OCommandContext ctx) ODDLStatement.createExecutionPlan(OCommandContext ctx) ODeleteEdgeStatement.createExecutionPlan(OCommandContext ctx) ODeleteStatement.createExecutionPlan(OCommandContext ctx) ODeleteVertexStatement.createExecutionPlan(OCommandContext ctx) OExplainStatement.createExecutionPlan(OCommandContext ctx) OFindReferencesStatement.createExecutionPlan(OCommandContext ctx) OForEachBlock.createExecutionPlan(OCommandContext ctx) OIfStatement.createExecutionPlan(OCommandContext ctx) OInsertStatement.createExecutionPlan(OCommandContext ctx) OMatchStatement.createExecutionPlan(OCommandContext ctx) OMoveVertexStatement.createExecutionPlan(OCommandContext ctx) OProfileStatement.createExecutionPlan(OCommandContext ctx) OSelectStatement.createExecutionPlan(OCommandContext ctx) OSimpleExecStatement.createExecutionPlan(OCommandContext ctx) OStatement.createExecutionPlan(OCommandContext ctx) creates an execution plan for current statement, with profiling disabledOTraverseStatement.createExecutionPlan(OCommandContext ctx) OUpdateEdgeStatement.createExecutionPlan(OCommandContext ctx) OUpdateStatement.createExecutionPlan(OCommandContext ctx) OWhileBlock.createExecutionPlan(OCommandContext ctx) default OIndexStreamOBinaryCompareOperator.createStreamForIndex(OIndexInternal index, Object rightValue, boolean orderAsc, OCommandContext ctx) OContainsKeyOperator.createStreamForIndex(OIndexInternal index, Object rightValue, boolean orderAsc, OCommandContext ctx) OContainsValueOperator.createStreamForIndex(OIndexInternal index, Object rightValue, boolean orderAsc, OCommandContext ctx) OEqualsCompareOperator.createStreamForIndex(OIndexInternal index, Object rightValue, boolean orderAsc, OCommandContext ctx) OGeOperator.createStreamForIndex(OIndexInternal index, Object rightValue, boolean orderAsc, OCommandContext ctx) OGtOperator.createStreamForIndex(OIndexInternal index, Object rightValue, boolean orderAsc, OCommandContext ctx) OLeOperator.createStreamForIndex(OIndexInternal index, Object rightValue, boolean orderAsc, OCommandContext ctx) OLtOperator.createStreamForIndex(OIndexInternal index, Object rightValue, boolean orderAsc, OCommandContext ctx) 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(OResult currentRecord, OCommandContext ctx) OBatch.evaluate(OCommandContext ctx) booleanOBetweenCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOBinaryCondition.evaluate(OResult currentRecord, OCommandContext ctx) abstract booleanOBooleanExpression.evaluate(OResult currentRecord, OCommandContext ctx) booleanOContainsAllCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOContainsAnyCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOContainsCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOContainsTextCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOContainsValueCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOFalseExpression.evaluate(OResult currentRecord, OCommandContext ctx) booleanOInCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOInstanceofCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOIsDefinedCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOIsNotDefinedCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOIsNotNullCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOIsNullCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOMatchesCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanONotBlock.evaluate(OResult currentRecord, OCommandContext ctx) booleanONotInCondition.evaluate(OResult currentRecord, OCommandContext ctx) booleanOOrBlock.evaluate(OResult currentRecord, OCommandContext ctx) booleanOOrBlock.evaluate(Object currentRecord, OCommandContext ctx) booleanOParenthesisBlock.evaluate(OResult currentRecord, OCommandContext ctx) ORecordAttribute.evaluate(OElement iCurrentRecord, OCommandContext ctx) ORecordAttribute.evaluate(OResult iCurrentRecord, OCommandContext ctx) booleanOTrueExpression.evaluate(OResult currentRecord, OCommandContext ctx) OInCondition.evaluateLeft(OResult currentRecord, OCommandContext ctx) OInCondition.evaluateRight(OResult currentRecord, OCommandContext ctx) ORightBinaryCondition.evaluateRight(OResult currentRecord, OCommandContext ctx) OArrayConcatExpression.execute(OResult iCurrentRecord, OCommandContext ctx) OArrayRangeSelector.execute(OResult iCurrentRecord, Object result, OCommandContext ctx) OArraySingleValuesSelector.execute(OResult iCurrentRecord, Object iResult, OCommandContext ctx) OBaseExpression.execute(OResult iCurrentRecord, OCommandContext ctx) OBaseIdentifier.execute(OResult iCurrentRecord, OCommandContext ctx) booleanOBinaryCompareOperator.execute(Object left, Object right, OCommandContext ctx) OCollection.execute(OResult iCurrentRecord, OCommandContext ctx) booleanOContainsKeyOperator.execute(Object left, Object right, OCommandContext ctx) booleanOContainsValueOperator.execute(Object iLeft, Object iRight, OCommandContext ctx) booleanOEqualsCompareOperator.execute(Object iLeft, Object iRight, OCommandContext ctx) OExpression.execute(OResult iCurrentRecord, OCommandContext ctx) OFunctionCall.execute(OResult targetObjects, OCommandContext ctx) booleanOGeOperator.execute(Object iLeft, Object iRight, OCommandContext ctx) booleanOGtOperator.execute(Object iLeft, Object iRight, OCommandContext ctx) booleanOInOperator.execute(Object left, Object right, OCommandContext ctx) booleanOLeOperator.execute(Object iLeft, Object iRight, OCommandContext ctx) OLevelZeroIdentifier.execute(OResult iCurrentRecord, OCommandContext ctx) booleanOLikeOperator.execute(Object iLeft, Object iRight, OCommandContext ctx) booleanOLtOperator.execute(Object iLeft, Object iRight, OCommandContext ctx) booleanOLuceneOperator.execute(Object left, Object right, 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(OResult iCurrentRecord, Object result, OCommandContext ctx) booleanONearOperator.execute(Object left, Object right, OCommandContext ctx) booleanONeOperator.execute(Object left, Object right, OCommandContext ctx) booleanONeqOperator.execute(Object left, Object right, OCommandContext ctx) OParenthesisExpression.execute(OResult iCurrentRecord, OCommandContext ctx) OProjectionItem.execute(OResult iCurrentRecord, OCommandContext ctx) ORightBinaryCondition.execute(OResult iCurrentRecord, Object elementToFilter, OCommandContext ctx) booleanOScAndOperator.execute(Object iLeft, Object iRight, OCommandContext ctx) OStatement.execute(ODatabaseSession db, Object[] args, OCommandContext parentCtx, boolean usePlanCache) OStatement.execute(ODatabaseSession db, Map params, OCommandContext parentCtx, boolean usePlanCache) OSuffixIdentifier.execute(OCommandContext iCurrentRecord) 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) OValueExpression.execute(OResult iCurrentRecord, OCommandContext ctx) booleanOWithinOperator.execute(Object left, Object right, OCommandContext ctx) 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 OExecutionStreamODDLStatement.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) OHaRemoveServerStatement.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 OExecutionStreamOSimpleExecStatement.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) OAndBlock.extractRidRanges(OCommandContext ctx) OBooleanExpression.extractRidRanges(OCommandContext ctx) OOrBlock.extractRidRanges(OCommandContext ctx) OWhereClause.extractRidRanges(OCommandContext ctx) OAndBlock.findIndex(OIndexFinder info, OCommandContext ctx) OBetweenCondition.findIndex(OIndexFinder info, OCommandContext ctx) OBinaryCondition.findIndex(OIndexFinder info, OCommandContext ctx) OBooleanExpression.findIndex(OIndexFinder info, OCommandContext ctx) OContainsAnyCondition.findIndex(OIndexFinder info, OCommandContext ctx) OContainsCondition.findIndex(OIndexFinder info, OCommandContext ctx) OContainsTextCondition.findIndex(OIndexFinder info, OCommandContext ctx) OContainsValueCondition.findIndex(OIndexFinder info, OCommandContext ctx) OInCondition.findIndex(OIndexFinder info, OCommandContext ctx) OIsNullCondition.findIndex(OIndexFinder info, OCommandContext ctx) ONotBlock.findIndex(OIndexFinder info, OCommandContext ctx) OOrBlock.findIndex(OIndexFinder info, OCommandContext ctx) OParenthesisBlock.findIndex(OIndexFinder info, OCommandContext ctx) OWhereClause.findIndex(OIndexFinder info, OCommandContext ctx) static OInternalExecutionPlanOExecutionPlanCache.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) OArrayConcatExpression.getIndexKey(OCommandContext ctx) OBaseExpression.getIndexKey(OCommandContext ctx) OBaseIdentifier.getIndexKey(OCommandContext ctx) OCollection.getIndexKey(OCommandContext ctx) OExpression.getIndexKey(OCommandContext ctx) OFunctionCall.getIndexKey(OCommandContext ctx) OLevelZeroIdentifier.getIndexKey(OCommandContext ctx) OMathExpression.getIndexKey(OCommandContext ctx) OParenthesisExpression.getIndexKey(OCommandContext ctx) OSuffixIdentifier.getIndexKey(OCommandContext ctx) OExecutionPlanCache.getInternal(String statement, OCommandContext ctx, ODatabaseDocumentInternal db) OMatchFilter.getRid(OCommandContext context) OArrayNumberSelector.getValue(OResult 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) WhileStep.internalStart(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) 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) OStatement.resolvePlan(boolean useCache, 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) OContainsTextCondition.rightValue(OCommandContext ctx, boolean asc) OBetweenCondition.secondValue(OCommandContext ctx, boolean asc) voidOAllocation.setOn(OClass oClass, OCommandContext ctx) 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!!!OExplainExecutionPlan.start(OCommandContext ctx) OProfileExecutionPlan.start(OCommandContext ctx) OBetweenCondition.thirdValue(OCommandContext ctx, boolean asc) OJson.toDocument(OIdentifiable source, OCommandContext ctx) OJson.toMap(OResult source, OCommandContext ctx) OJson.toObjectDetermineType(OResult source, OCommandContext ctx) choosing return type is based on existence of @class and @type field in JSONORid.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) -
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.server.distributed.impl.task
Methods in com.orientechnologies.orient.server.distributed.impl.task with parameters of type OCommandContextModifier and TypeMethodDescriptionvoidOExecutionStreamDistributedFetch.close(OCommandContext ctx) booleanOExecutionStreamDistributedFetch.hasNext(OCommandContext ctx) OExecutionStreamDistributedFetch.next(OCommandContext ctx) -
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) protected OLuceneSpatialIndexOSpatialFunctionAbstractIndexable.searchForIndex(OFromClause target, OExpression[] args, OCommandContext ctx) 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 TypeMethodDescriptionbooleanOLuceneNearOperator.evaluate(Object iLeft, Object iRight, OCommandContext ctx) booleanOLuceneOverlapOperator.evaluate(Object iLeft, Object iRight, OCommandContext ctx) booleanOLuceneWithinOperator.evaluate(Object iLeft, Object iRight, OCommandContext ctx) -
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 org.apache.tinkerpop.gremlin.orientdb.executor
Methods in org.apache.tinkerpop.gremlin.orientdb.executor with parameters of type OCommandContextModifier and TypeMethodDescriptionOCommandGremlinExecutor.executeFunction(OCommandContext context, String functionName, Map<Object, Object> iArgs)