Constructor and Description |
---|
OContextVariableResolver(OCommandContext iContext) |
Modifier and Type | Method and Description |
---|---|
OCommandContext |
OLuceneCompositeKey.getContext() |
Modifier and Type | Method and Description |
---|---|
void |
OLuceneResultSet.sendLookupTime(OCommandContext commandContext,
long start) |
OLuceneCompositeKey |
OLuceneCompositeKey.setContext(OCommandContext context) |
Modifier and Type | Method and Description |
---|---|
static void |
OLuceneIndexEngineUtils.sendLookupTime(String indexName,
OCommandContext context,
org.apache.lucene.search.TopDocs docs,
Integer limit,
long startFetching) |
static void |
OLuceneIndexEngineUtils.sendTotalHits(String indexName,
OCommandContext context,
long totalHits) |
Modifier and Type | Method and Description |
---|---|
boolean |
OLuceneSearchFunctionTemplate.allowsIndexedExecution(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
boolean |
OLuceneSearchMoreLikeThisFunction.allowsIndexedExecution(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
boolean |
OLuceneSearchFunctionTemplate.canExecuteInline(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
boolean |
OLuceneSearchMoreLikeThisFunction.canExecuteInline(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
long |
OLuceneSearchFunctionTemplate.estimate(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
long |
OLuceneSearchMoreLikeThisFunction.estimate(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
Object |
OLuceneSearchOnClassFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] params,
OCommandContext ctx) |
Object |
OLuceneSearchOnIndexFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] params,
OCommandContext ctx) |
Object |
OLuceneSearchOnFieldsFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] params,
OCommandContext ctx) |
Object |
OLuceneSearchMoreLikeThisFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] params,
OCommandContext ctx) |
protected static OLuceneFullTextIndex |
OLuceneFunctionsUtils.getLuceneFullTextIndex(OCommandContext ctx,
String indexName) |
static org.apache.lucene.index.memory.MemoryIndex |
OLuceneFunctionsUtils.getOrCreateMemoryIndex(OCommandContext ctx) |
protected static OLuceneFullTextIndex |
OLuceneFunctionsUtils.searchForIndex(OExpression[] args,
OCommandContext ctx) |
protected abstract OLuceneFullTextIndex |
OLuceneSearchFunctionTemplate.searchForIndex(OFromClause target,
OCommandContext ctx,
OExpression... args) |
protected OLuceneFullTextIndex |
OLuceneSearchOnClassFunction.searchForIndex(OFromClause target,
OCommandContext ctx,
OExpression... args) |
protected OLuceneFullTextIndex |
OLuceneSearchOnIndexFunction.searchForIndex(OFromClause target,
OCommandContext ctx,
OExpression... args) |
protected OLuceneFullTextIndex |
OLuceneSearchOnFieldsFunction.searchForIndex(OFromClause target,
OCommandContext ctx,
OExpression... args) |
Iterable<OIdentifiable> |
OLuceneSearchOnClassFunction.searchFromTarget(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
Iterable<OIdentifiable> |
OLuceneSearchOnIndexFunction.searchFromTarget(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
Iterable<OIdentifiable> |
OLuceneSearchOnFieldsFunction.searchFromTarget(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
Iterable<OIdentifiable> |
OLuceneSearchMoreLikeThisFunction.searchFromTarget(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
boolean |
OLuceneSearchFunctionTemplate.shouldExecuteAfterSearch(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
boolean |
OLuceneSearchMoreLikeThisFunction.shouldExecuteAfterSearch(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
Modifier and Type | Method and Description |
---|---|
static OIndexSearchResult |
OLuceneOperatorUtil.buildOIndexSearchResult(OClass iSchemaClass,
OSQLFilterCondition iCondition,
List<OIndexSearchResult> iIndexSearchResults,
OCommandContext context) |
Object |
OLuceneTextOperator.evaluateRecord(OIdentifiable iRecord,
ODocument iCurrentResult,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext,
ODocumentSerializer serializer) |
Stream<ORawPair<Object,ORID>> |
OLuceneTextOperator.executeIndexQuery(OCommandContext iContext,
OIndex index,
List<Object> keyParams,
boolean ascSortOrder) |
OIndexSearchResult |
OLuceneTextOperator.getOIndexSearchResult(OClass iSchemaClass,
OSQLFilterCondition iCondition,
List<OIndexSearchResult> iIndexSearchResults,
OCommandContext context) |
Modifier and Type | Method and Description |
---|---|
OCommandContext |
OLuceneQueryContext.getContext() |
Constructor and Description |
---|
OLuceneQueryContext(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) |
Modifier and Type | Class and Description |
---|---|
class |
OBasicCommandContext
Basic implementation of OCommandContext interface that stores variables in a map.
|
Modifier and Type | Field and Description |
---|---|
protected OCommandContext |
OBasicCommandContext.child |
protected OCommandContext |
OCommandRequestAbstract.context |
protected OCommandContext |
OCommandExecutorAbstract.context |
protected OCommandContext |
OBasicCommandContext.parent |
Modifier and Type | Method and Description |
---|---|
OCommandContext |
OBasicCommandContext.copy() |
OCommandContext |
OCommandContext.copy()
Creates a copy of execution context.
|
OCommandContext |
OCommandRequestAbstract.getContext() |
OCommandContext |
OCommandRequest.getContext() |
OCommandContext |
OCommandExecutor.getContext() |
OCommandContext |
OCommandExecutorAbstract.getContext() |
OCommandContext |
OCommand.getContext() |
OCommandContext |
OBasicCommandContext.getParent() |
OCommandContext |
OCommandContext.getParent() |
OCommandContext |
OBasicCommandContext.incrementVariable(String iName) |
OCommandContext |
OCommandContext.incrementVariable(String getNeighbors) |
OCommandContext |
OBasicCommandContext.setChild(OCommandContext iContext)
Set the inherited context avoiding to copy all the values every time.
|
OCommandContext |
OCommandContext.setChild(OCommandContext context) |
OCommandContext |
OBasicCommandContext.setParent(OCommandContext iParentContext) |
OCommandContext |
OCommandContext.setParent(OCommandContext iParentContext) |
OCommandContext |
OBasicCommandContext.setParentWithoutOverridingChild(OCommandContext iParentContext) |
OCommandContext |
OBasicCommandContext.setRecordingMetrics(boolean recordMetrics) |
OCommandContext |
OCommandContext.setRecordingMetrics(boolean recordMetrics) |
OCommandContext |
OBasicCommandContext.setVariable(String iName,
Object iValue) |
OCommandContext |
OCommandContext.setVariable(String iName,
Object iValue) |
Modifier and Type | Method and Description |
---|---|
static boolean |
OCommandExecutorAbstract.checkInterruption(OCommandContext iContext) |
Object |
OCommandPredicate.evaluate(OIdentifiable iRecord,
ODocument iCurrentResult,
OCommandContext iContext)
Evaluates the predicate.
|
void |
OBasicCommandContext.merge(OCommandContext iContext) |
void |
OCommandContext.merge(OCommandContext iContext)
Merges a context with current one.
|
OCommandContext |
OBasicCommandContext.setChild(OCommandContext iContext)
Set the inherited context avoiding to copy all the values every time.
|
OCommandContext |
OCommandContext.setChild(OCommandContext context) |
OCommandRequestAbstract |
OCommandRequestAbstract.setContext(OCommandContext iContext) |
OCommandRequest |
OCommandRequest.setContext(OCommandContext iContext) |
void |
OCommandExecutor.setContext(OCommandContext context) |
void |
OCommandExecutorAbstract.setContext(OCommandContext iContext) |
OCommandContext |
OBasicCommandContext.setParent(OCommandContext iParentContext) |
OCommandContext |
OCommandContext.setParent(OCommandContext iParentContext) |
OCommandContext |
OBasicCommandContext.setParentWithoutOverridingChild(OCommandContext iParentContext) |
Modifier and Type | Class and Description |
---|---|
class |
OTraverseContext |
Modifier and Type | Method and Description |
---|---|
Object |
ODatabaseFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iFuncParams,
OCommandContext iContext) |
Object |
OFunction.executeInContext(OCommandContext iContext,
Map<String,Object> iArgs)
Deprecated.
|
Object |
OFunction.executeInContext(OCommandContext iContext,
Object... iArgs)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
Object |
ODocument.eval(String iExpression,
OCommandContext iContext)
Evaluates a SQL expression against current document by passing a context.
|
static Object |
ODocumentHelper.evaluateFunction(Object currentValue,
String iFunction,
OCommandContext iContext) |
static <RET> RET |
ODocumentHelper.getFieldValue(Object value,
String iFieldName,
OCommandContext iContext) |
protected static Object |
ODocumentHelper.getIndexPart(OCommandContext iContext,
String indexPart) |
static void |
ODocumentHelper.sort(List<? extends OIdentifiable> ioResultSet,
List<OPair<String,String>> iOrderCriteria,
OCommandContext context) |
Constructor and Description |
---|
ODocumentComparator(List<OPair<String,String>> iOrderCriteria,
OCommandContext iContext) |
Modifier and Type | Field and Description |
---|---|
protected OCommandContext |
OMetricRecorder.context |
Modifier and Type | Method and Description |
---|---|
OCommandContext |
OCommandExecutorSQLTraverse.getContext() |
OCommandContext |
OCommandExecutorToOStatementWrapper.getContext() |
OCommandContext |
OCommandExecutorSQLDelegate.getContext() |
Modifier and Type | Method and Description |
---|---|
protected boolean |
OCommandExecutorSQLSelect.addResult(OIdentifiable iRecord,
OCommandContext iContext) |
List<OIndexSearchResult> |
OFilterAnalyzer.analyzeCondition(OSQLFilterCondition condition,
OClass schemaClass,
OCommandContext context)
Analyzes a query filter for a possible indexation options.
|
List<List<OIndexSearchResult>> |
OFilterAnalyzer.analyzeMainCondition(OSQLFilterCondition condition,
OClass schemaClass,
OCommandContext context) |
static ODocument |
ORuntimeResult.applyRecord(ODocument iValue,
Map<String,Object> iProjections,
OCommandContext iContext,
OIdentifiable iRecord) |
static ODocument |
OSQLHelper.bindParameters(ODocument iDocument,
List<OPair<String,Object>> iFields,
OCommandParameters iArguments,
OCommandContext iContext) |
static ODocument |
OSQLHelper.bindParameters(ODocument iDocument,
Map<String,Object> iFields,
OCommandParameters iArguments,
OCommandContext iContext) |
protected boolean |
OCommandExecutorSQLResultsetAbstract.evaluateRecord(ORecord iRecord,
OCommandContext iContext) |
protected boolean |
OCommandExecutorSQLSelect.executeSearchRecord(OIdentifiable id,
OCommandContext iContext,
boolean callHooks) |
protected boolean |
OCommandExecutorSQLResultsetAbstract.filter(ORecord iRecord,
OCommandContext iContext) |
static Object |
OSQLEngine.foreachRecord(OCallable<Object,OIdentifiable> iCallable,
Object iCurrent,
OCommandContext iContext) |
protected ORuntimeResult |
OCommandExecutorSQLSelect.getProjectionGroup(Object fieldValue,
OCommandContext iContext) |
static ODocument |
ORuntimeResult.getProjectionResult(int iId,
Map<String,Object> iProjections,
OCommandContext iContext,
OIdentifiable iRecord) |
int |
OTemporaryRidGenerator.getTemporaryRIDCounter(OCommandContext iContext) |
int |
OCommandExecutorSQLSelect.getTemporaryRIDCounter(OCommandContext iContext)
Returns the temporary RID counter assuring it's unique per query tree.
|
static Object |
OSQLHelper.getValue(Object iObject,
ORecord iRecord,
OCommandContext iContext) |
protected boolean |
OCommandExecutorSQLResultsetAbstract.handleResult(OIdentifiable iRecord,
OCommandContext iContext) |
protected boolean |
OCommandExecutorSQLSelect.handleResult(OIdentifiable iRecord,
OCommandContext iContext)
Handles the record in result.
|
OSQLFilter |
OSQLEngine.parseCondition(String iText,
OCommandContext iContext,
String iFilterKeyword) |
Set<OIdentifiable> |
OSQLEngine.parseRIDTarget(ODatabaseDocument database,
String iTarget,
OCommandContext iContext,
Map<Object,Object> iArgs) |
OSQLTarget |
OSQLEngine.parseTarget(String iText,
OCommandContext iContext) |
static Object |
OSQLHelper.parseValue(OBaseParser iCommand,
String iWord,
OCommandContext iContext) |
static Object |
OSQLHelper.parseValue(OBaseParser iCommand,
String iWord,
OCommandContext iContext,
boolean resolveContextVariables) |
static Object |
OSQLHelper.parseValue(OSQLPredicate iSQLFilter,
OBaseParser iCommand,
String iWord,
OCommandContext iContext) |
static Object |
OSQLHelper.parseValue(String iValue,
OCommandContext iContext)
Convert fields from text to real value.
|
static Object |
OSQLHelper.parseValue(String iValue,
OCommandContext iContext,
boolean resolveContextVariables) |
static Object |
OSQLHelper.resolveFieldValue(ODocument iDocument,
String iFieldName,
Object iFieldValue,
OCommandParameters iArguments,
OCommandContext iContext) |
protected void |
OCommandExecutorSQLSelect.revertProfiler(OCommandContext iContext,
OIndex index,
List<Object> keyParams,
OIndexDefinition indexDefinition) |
protected void |
OCommandExecutorSQLSelect.revertSubclassesProfiler(OCommandContext iContext,
int num) |
void |
OMetricRecorder.setContext(OCommandContext context) |
void |
OCommandExecutorToOStatementWrapper.setContext(OCommandContext context) |
Constructor and Description |
---|
OOriginalRecordsReturnHandler(Object returnExpression,
OCommandContext context) |
ORecordsReturnHandler(Object returnExpression,
OCommandContext context) |
ORuntimeResult(Object iFieldValue,
Map<String,Object> iProjections,
int iProgressive,
OCommandContext iContext) |
OUpdatedRecordsReturnHandler(Object returnExpression,
OCommandContext context) |
Modifier and Type | Field and Description |
---|---|
protected OCommandContext |
AbstractExecutionStep.ctx |
Modifier and Type | Method and Description |
---|---|
OCommandContext |
AbstractExecutionStep.getContext() |
Modifier and Type | Method and Description |
---|---|
void |
OFuncitonAggregationContext.apply(OResult next,
OCommandContext ctx) |
void |
AggregationContext.apply(OResult next,
OCommandContext ctx) |
OExecutionStep |
CreateEdgesStep.copy(OCommandContext ctx) |
default OExecutionStep |
OExecutionStepInternal.copy(OCommandContext ctx) |
OExecutionStep |
CastToEdgeStep.copy(OCommandContext ctx) |
OExecutionStep |
FilterByClassStep.copy(OCommandContext ctx) |
OExecutionStep |
AccumulatingTimeoutStep.copy(OCommandContext ctx) |
OExecutionStep |
SaveElementStep.copy(OCommandContext ctx) |
OExecutionStep |
EmptyStep.copy(OCommandContext ctx) |
OExecutionStep |
FilterStep.copy(OCommandContext ctx) |
OInternalExecutionPlan |
ODeleteExecutionPlan.copy(OCommandContext ctx) |
OExecutionStep |
SubQueryStep.copy(OCommandContext ctx) |
OExecutionStep |
FetchFromIndexStep.copy(OCommandContext ctx) |
OExecutionStep |
GlobalLetExpressionStep.copy(OCommandContext ctx) |
OExecutionStep |
FetchTemporaryFromTxStep.copy(OCommandContext ctx) |
OExecutionStep |
GetValueFromIndexEntryStep.copy(OCommandContext ctx) |
OExecutionStep |
ProjectionCalculationStep.copy(OCommandContext ctx) |
OExecutionStep |
AggregateProjectionCalculationStep.copy(OCommandContext ctx) |
OExecutionStep |
TimeoutStep.copy(OCommandContext ctx) |
OExecutionStep |
DeleteStep.copy(OCommandContext ctx) |
OExecutionStep |
FetchFromClusterExecutionStep.copy(OCommandContext ctx) |
OExecutionStep |
ParallelExecStep.copy(OCommandContext ctx) |
OInternalExecutionPlan |
OUpdateExecutionPlan.copy(OCommandContext ctx) |
OExecutionStep |
CountStep.copy(OCommandContext ctx) |
OExecutionStep |
FetchFromClassExecutionStep.copy(OCommandContext ctx) |
OInternalExecutionPlan |
OInsertExecutionPlan.copy(OCommandContext ctx) |
default OInternalExecutionPlan |
OInternalExecutionPlan.copy(OCommandContext ctx) |
OExecutionStep |
FetchEdgesFromToVerticesStep.copy(OCommandContext ctx) |
OExecutionStep |
GuaranteeEmptyCountStep.copy(OCommandContext ctx) |
OInternalExecutionPlan |
OSelectExecutionPlan.copy(OCommandContext ctx) |
OExecutionStep |
CheckClassTypeStep.copy(OCommandContext ctx) |
protected void |
OSelectExecutionPlan.copyOn(OSelectExecutionPlan copy,
OCommandContext ctx) |
int |
IndexSearchDescriptor.cost(OCommandContext ctx) |
OUpdateExecutionPlan |
OMoveVertexExecutionPlanner.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OInsertExecutionPlan |
OInsertExecutionPlanner.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
ODeleteExecutionPlan |
ODeleteExecutionPlanner.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OInternalExecutionPlan |
OFindReferencesExecutionPlanner.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
ODeleteExecutionPlan |
ODeleteVertexExecutionPlanner.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OUpdateExecutionPlan |
OUpdateExecutionPlanner.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OInternalExecutionPlan |
OTraverseExecutionPlanner.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OInternalExecutionPlan |
OMatchExecutionPlanner.createExecutionPlan(OCommandContext context,
boolean enableProfiling) |
OInsertExecutionPlan |
OCreateVertexExecutionPlanner.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OInternalExecutionPlan |
OSelectExecutionPlanner.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling,
boolean useCache) |
OInsertExecutionPlan |
OCreateEdgeExecutionPlanner.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling,
boolean useCache) |
OInternalExecutionPlan |
ODeleteEdgeExecutionPlanner.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling,
boolean useCache) |
protected Iterable<OResultInternal> |
MatchEdgeTraverser.executeTraversal(OCommandContext iCommandContext,
OMatchPathItem item,
OIdentifiable startingPoint,
int depth,
List<OIdentifiable> pathToHere) |
Iterable<OIdentifiable> |
PatternEdge.executeTraversal(OMatchStatement.MatchContext matchContext,
OCommandContext iCommandContext,
OIdentifiable startingPoint,
int depth) |
OExecutionStepInternal |
ScriptLineStep.executeUntilReturn(OCommandContext ctx) |
protected void |
BreadthFirstTraverseStep.fetchNextEntryPoints(OCommandContext ctx,
int nRecords) |
protected abstract void |
AbstractTraverseStep.fetchNextEntryPoints(OCommandContext ctx,
int nRecords) |
protected void |
DepthFirstTraverseStep.fetchNextEntryPoints(OCommandContext ctx,
int nRecords) |
protected void |
BreadthFirstTraverseStep.fetchNextResults(OCommandContext ctx,
int nRecords) |
protected abstract void |
AbstractTraverseStep.fetchNextResults(OCommandContext ctx,
int nRecords) |
protected void |
DepthFirstTraverseStep.fetchNextResults(OCommandContext ctx,
int nRecords) |
static void |
OSelectExecutionPlanner.handleOrderBy(OSelectExecutionPlan plan,
QueryPlanningInfo info,
OCommandContext ctx,
boolean profilingEnabled) |
static void |
OSelectExecutionPlanner.handleProjectionsBlock(OSelectExecutionPlan result,
QueryPlanningInfo info,
OCommandContext ctx,
boolean enableProfiling) |
static void |
OSelectExecutionPlanner.handleUnwind(OSelectExecutionPlan result,
QueryPlanningInfo info,
OCommandContext ctx,
boolean profilingEnabled) |
boolean |
MatchEdgeTraverser.hasNext(OCommandContext ctx) |
protected void |
OptionalMatchEdgeTraverser.init(OCommandContext ctx) |
protected void |
MatchEdgeTraverser.init(OCommandContext ctx) |
protected void |
ForEachStep.init(OCommandContext ctx) |
protected void |
IfStep.init(OCommandContext ctx) |
void |
DistributedExecutionStep.init(OCommandContext ctx) |
void |
IfStep.initNegativePlan(OCommandContext ctx) |
OScriptExecutionPlan |
RetryStep.initPlan(List<OStatement> body,
OCommandContext ctx) |
OScriptExecutionPlan |
ForEachStep.initPlan(OCommandContext ctx) |
void |
IfStep.initPositivePlan(OCommandContext ctx) |
protected OView |
FetchFromViewExecutionStep.loadClassFromSchema(String className,
OCommandContext ctx) |
protected OClass |
FetchFromClassExecutionStep.loadClassFromSchema(String className,
OCommandContext ctx) |
protected boolean |
MatchEdgeTraverser.matchesFilters(OCommandContext iCommandContext,
OWhereClause filter,
OIdentifiable origin) |
OResult |
OptionalMatchEdgeTraverser.next(OCommandContext ctx) |
OResult |
MatchEdgeTraverser.next(OCommandContext ctx) |
protected static void |
OSelectExecutionPlanner.optimizeQuery(QueryPlanningInfo info,
OCommandContext ctx) |
void |
OSingleOpExecutionPlan.reset(OCommandContext ctx) |
void |
OIfExecutionPlan.reset(OCommandContext ctx) |
void |
ODDLExecutionPlan.reset(OCommandContext ctx) |
void |
OScriptExecutionPlan.reset(OCommandContext ctx) |
void |
OUpdateExecutionPlan.reset(OCommandContext ctx) |
void |
OInsertExecutionPlan.reset(OCommandContext ctx) |
void |
OInternalExecutionPlan.reset(OCommandContext ctx) |
void |
OSelectExecutionPlan.reset(OCommandContext ctx) |
OResultSet |
DeleteFromIndexStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
InsertValuesStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
MatchFirstStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
ScriptLineStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
FetchEdgesToVerticesStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
CartesianProductStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
FindReferencesStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
MatchStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
CreateEdgesStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
OExecutionStepInternal.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
OrderByStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
RemoveEmptyOptionalsStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
CastToEdgeStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
LetQueryStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
FilterByClassStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
AccumulatingTimeoutStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
SaveElementStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
MatchPrefetchStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
MoveVertexStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
AbstractUnrollStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
AbstractTraverseStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
UnwrapPreviousValueStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
EmptyStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
RetryStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
FilterStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
UpsertStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
SubQueryStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
FetchFromRidsStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
FetchFromIndexStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
CountFromIndexStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
GlobalLetExpressionStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
UpdateRemoveStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
CheckSafeDeleteStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
CopyDocumentStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
FilterNotMatchPatternStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
FetchTemporaryFromTxStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
CreateRecordStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
GlobalLetQueryStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
GetValueFromIndexEntryStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
CopyRecordContentBeforeUpdateStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
DistinctExecutionStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
CheckClusterTypeStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
BatchStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
ProjectionCalculationStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
FetchFromClustersExecutionStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
ReturnStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
UnwindStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
AggregateProjectionCalculationStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
CastToVertexStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
RemoveEdgePointersStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
TimeoutStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
ReturnMatchPatternsStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
ForEachStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
LockRecordStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
DeleteStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
CheckRecordTypeStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
FetchFromVariableStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
UpdateMergeStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
FetchFromClusterExecutionStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
SetDocumentClassStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
ExpandStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
IfStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
ParallelExecStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
FetchFromDatabaseMetadataStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
UpdateSetStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
ConvertToUpdatableResultStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
CountStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
LetExpressionStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
FetchFromClassExecutionStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
InsertIntoIndexStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
SkipExecutionStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
FilterByClustersStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
LimitExecutionStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
CountFromClassStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
ReturnMatchPathsStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
FetchEdgesFromToVerticesStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
GuaranteeEmptyCountStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
FetchFromIndexedFunctionStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
UpdateContentStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
ConvertToResultInternalStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
DistributedExecutionStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
CheckClassTypeStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
UpdateEdgePointersStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
EmptyDataGeneratorStep.syncPull(OCommandContext ctx,
int nRecords) |
OResultSet |
FetchFromStorageMetadataStep.syncPull(OCommandContext ctx,
int nRecords) |
protected String |
MatchEdgeTraverser.targetClassName(OMatchPathItem item,
OCommandContext iCommandContext) |
protected String |
MatchReverseEdgeTraverser.targetClassName(OMatchPathItem item,
OCommandContext iCommandContext) |
protected String |
MatchEdgeTraverser.targetClusterName(OMatchPathItem item,
OCommandContext iCommandContext) |
protected String |
MatchReverseEdgeTraverser.targetClusterName(OMatchPathItem item,
OCommandContext iCommandContext) |
protected ORid |
MatchEdgeTraverser.targetRid(OMatchPathItem item,
OCommandContext iCommandContext) |
protected ORid |
MatchReverseEdgeTraverser.targetRid(OMatchPathItem item,
OCommandContext iCommandContext) |
protected Iterable<OResultInternal> |
MatchFieldTraverser.traversePatternEdge(OIdentifiable startingPoint,
OCommandContext iCommandContext) |
protected Iterable<OResultInternal> |
MatchEdgeTraverser.traversePatternEdge(OIdentifiable startingPoint,
OCommandContext iCommandContext) |
protected Iterable<OResultInternal> |
MatchReverseEdgeTraverser.traversePatternEdge(OIdentifiable startingPoint,
OCommandContext iCommandContext) |
protected Iterable<OResultInternal> |
MatchMultiEdgeTraverser.traversePatternEdge(OIdentifiable startingPoint,
OCommandContext iCommandContext) |
protected Collection<OResult> |
WhileMatchStep.unroll(OResult doc,
OCommandContext iContext) |
protected abstract Collection<OResult> |
AbstractUnrollStep.unroll(OResult doc,
OCommandContext iContext) |
protected Collection<OResult> |
ReturnMatchPathElementsStep.unroll(OResult doc,
OCommandContext iContext) |
protected Collection<OResult> |
ReturnMatchElementsStep.unroll(OResult doc,
OCommandContext iContext) |
Constructor and Description |
---|
AbstractExecutionStep(OCommandContext ctx,
boolean profilingEnabled) |
AbstractTraverseStep(List<OTraverseProjectionItem> projections,
OWhereClause whileClause,
OInteger maxDepth,
OCommandContext ctx,
boolean profilingEnabled) |
AbstractUnrollStep(OCommandContext ctx,
boolean profilingEnabled) |
AccumulatingTimeoutStep(OTimeout timeout,
OCommandContext ctx,
boolean profilingEnabled) |
AggregateProjectionCalculationStep(OProjection projection,
OGroupBy groupBy,
OCommandContext ctx,
long timeoutMillis,
boolean profilingEnabled) |
BatchStep(OBatch batch,
OCommandContext ctx,
boolean profilingEnabled) |
BreadthFirstTraverseStep(List<OTraverseProjectionItem> projections,
OWhereClause whileClause,
OInteger maxDepth,
OCommandContext ctx,
boolean profilingEnabled) |
CartesianProductStep(OCommandContext ctx,
boolean profilingEnabled) |
CastToEdgeStep(OCommandContext ctx,
boolean profilingEnabled) |
CastToVertexStep(OCommandContext ctx,
boolean profilingEnabled) |
CheckClassTypeStep(String targetClass,
String parentClass,
OCommandContext ctx,
boolean profilingEnabled) |
CheckClusterTypeStep(OCluster targetCluster,
String clazz,
OCommandContext ctx,
boolean profilingEnabled) |
CheckClusterTypeStep(String targetClusterName,
String clazz,
OCommandContext ctx,
boolean profilingEnabled) |
CheckRecordTypeStep(OCommandContext ctx,
String className,
boolean profilingEnabled) |
CheckSafeDeleteStep(OCommandContext ctx,
boolean profilingEnabled) |
ConvertToResultInternalStep(OCommandContext ctx,
boolean profilingEnabled) |
ConvertToUpdatableResultStep(OCommandContext ctx,
boolean profilingEnabled) |
CopyDocumentStep(OCommandContext ctx,
boolean profilingEnabled) |
CopyRecordContentBeforeUpdateStep(OCommandContext ctx,
boolean profilingEnabled) |
CountFromClassStep(OIdentifier targetClass,
String alias,
OCommandContext ctx,
boolean profilingEnabled) |
CountFromIndexStep(OIndexIdentifier targetIndex,
String alias,
OCommandContext ctx,
boolean profilingEnabled) |
CountStep(OCommandContext ctx,
boolean profilingEnabled) |
CreateEdgesStep(OIdentifier targetClass,
OIdentifier targetClusterName,
String uniqueIndex,
OIdentifier fromAlias,
OIdentifier toAlias,
Number wait,
Number retry,
OBatch batch,
OCommandContext ctx,
boolean profilingEnabled) |
CreateRecordStep(OCommandContext ctx,
int total,
boolean profilingEnabled) |
DeleteFromIndexStep(OIndex index,
OBooleanExpression condition,
OBinaryCondition additionalRangeCondition,
OBooleanExpression ridCondition,
OCommandContext ctx,
boolean profilingEnabled) |
DeleteStep(OCommandContext ctx,
boolean profilingEnabled) |
DepthFirstTraverseStep(List<OTraverseProjectionItem> projections,
OWhereClause whileClause,
OInteger maxDepth,
OCommandContext ctx,
boolean profilingEnabled) |
DistinctExecutionStep(OCommandContext ctx,
boolean profilingEnabled) |
DistributedExecutionStep(OSelectExecutionPlan subExecutionPlan,
String nodeName,
OCommandContext ctx,
boolean profilingEnabled) |
EmptyDataGeneratorStep(int size,
OCommandContext ctx,
boolean profilingEnabled) |
EmptyStep(OCommandContext ctx,
boolean profilingEnabled) |
ExpandStep(OCommandContext ctx,
boolean profilingEnabled) |
FetchEdgesFromToVerticesStep(String fromAlias,
String toAlias,
OIdentifier targetClass,
OIdentifier targetCluster,
OCommandContext ctx,
boolean profilingEnabled) |
FetchEdgesToVerticesStep(String toAlias,
OIdentifier targetClass,
OIdentifier targetCluster,
OCommandContext ctx,
boolean profilingEnabled) |
FetchFromClassExecutionStep(OCommandContext ctx,
boolean profilingEnabled) |
FetchFromClassExecutionStep(String className,
Set<String> clusters,
OCommandContext ctx,
Boolean ridOrder,
boolean profilingEnabled) |
FetchFromClassExecutionStep(String className,
Set<String> clusters,
QueryPlanningInfo planningInfo,
OCommandContext ctx,
Boolean ridOrder,
boolean profilingEnabled)
iterates over a class and its subclasses
|
FetchFromClusterExecutionStep(int clusterId,
OCommandContext ctx,
boolean profilingEnabled) |
FetchFromClusterExecutionStep(int clusterId,
QueryPlanningInfo queryPlanning,
OCommandContext ctx,
boolean profilingEnabled) |
FetchFromClustersExecutionStep(int[] clusterIds,
OCommandContext ctx,
Boolean ridOrder,
boolean profilingEnabled)
iterates over a class and its subclasses
|
FetchFromDatabaseMetadataStep(OCommandContext ctx,
boolean profilingEnabled) |
FetchFromIndexedFunctionStep(OBinaryCondition functionCondition,
OFromClause queryTarget,
OCommandContext ctx,
boolean profilingEnabled) |
FetchFromIndexStep(OIndex index,
OBooleanExpression condition,
OBinaryCondition additionalRangeCondition,
boolean orderAsc,
OCommandContext ctx,
boolean profilingEnabled) |
FetchFromIndexStep(OIndex index,
OBooleanExpression condition,
OBinaryCondition additionalRangeCondition,
OCommandContext ctx,
boolean profilingEnabled) |
FetchFromIndexValuesStep(OIndex index,
boolean asc,
OCommandContext ctx,
boolean profilingEnabled) |
FetchFromRidsStep(Collection<ORecordId> rids,
OCommandContext ctx,
boolean profilingEnabled) |
FetchFromStorageMetadataStep(OCommandContext ctx,
boolean profilingEnabled) |
FetchFromVariableStep(String variableName,
OCommandContext ctx,
boolean profilingEnabled) |
FetchFromViewExecutionStep(String className,
Set<String> clusters,
QueryPlanningInfo planningInfo,
OCommandContext ctx,
Boolean ridOrder,
boolean profilingEnabled) |
FetchTemporaryFromTxStep(OCommandContext ctx,
String className,
boolean profilingEnabled) |
FilterByClassStep(OIdentifier identifier,
OCommandContext ctx,
boolean profilingEnabled) |
FilterByClustersStep(Set<String> filterClusters,
OCommandContext ctx,
boolean profilingEnabled) |
FilterNotMatchPatternStep(List<AbstractExecutionStep> steps,
OCommandContext ctx,
boolean enableProfiling) |
FilterStep(OWhereClause whereClause,
OCommandContext ctx,
long timeoutMillis,
boolean profilingEnabled) |
FindReferencesStep(List<OIdentifier> classes,
List<OCluster> clusters,
OCommandContext ctx,
boolean profilingEnabled) |
ForEachStep(OIdentifier loopVariable,
OExpression oExpression,
List<OStatement> statements,
OCommandContext ctx,
boolean enableProfiling) |
GetValueFromIndexEntryStep(OCommandContext ctx,
int[] filterClusterIds,
boolean profilingEnabled) |
GlobalLetExpressionStep(OIdentifier varName,
OExpression expression,
OCommandContext ctx,
boolean profilingEnabled) |
GlobalLetQueryStep(OIdentifier varName,
OStatement query,
OCommandContext ctx,
boolean profilingEnabled,
List<String> scriptVars) |
GuaranteeEmptyCountStep(OProjectionItem oProjectionItem,
OCommandContext ctx,
boolean enableProfiling) |
IfStep(OCommandContext ctx,
boolean profilingEnabled) |
InsertIntoIndexStep(OIndexIdentifier targetIndex,
OInsertBody insertBody,
OCommandContext ctx,
boolean profilingEnabled) |
InsertValuesStep(List<OIdentifier> identifierList,
List<List<OExpression>> valueExpressions,
OCommandContext ctx,
boolean profilingEnabled) |
LetExpressionStep(OIdentifier varName,
OExpression expression,
OCommandContext ctx,
boolean profilingEnabled) |
LetQueryStep(OIdentifier varName,
OStatement query,
OCommandContext ctx,
boolean profilingEnabled) |
LimitExecutionStep(OLimit limit,
OCommandContext ctx,
boolean profilingEnabled) |
LockRecordStep(OStorage.LOCKING_STRATEGY lockStrategy,
OCommandContext ctx,
boolean enableProfiling) |
MatchFirstStep(OCommandContext context,
PatternNode node,
boolean profilingEnabled) |
MatchFirstStep(OCommandContext context,
PatternNode node,
OInternalExecutionPlan subPlan,
boolean profilingEnabled) |
MatchPrefetchStep(OCommandContext ctx,
OInternalExecutionPlan prefetchExecPlan,
String alias,
boolean profilingEnabled) |
MatchStep(OCommandContext context,
EdgeTraversal edge,
boolean profilingEnabled) |
MoveVertexStep(OIdentifier targetClass,
OCluster targetCluster,
OCommandContext ctx,
boolean profilingEnabled) |
ODDLExecutionPlan(OCommandContext ctx,
ODDLStatement stm) |
ODeleteExecutionPlan(OCommandContext ctx) |
OForEachExecutionPlan(OCommandContext ctx) |
OIfExecutionPlan(OCommandContext ctx) |
OInsertExecutionPlan(OCommandContext ctx) |
OptionalMatchStep(OCommandContext context,
EdgeTraversal edge,
boolean profilingEnabled) |
OrderByStep(OOrderBy orderBy,
Integer maxResults,
OCommandContext ctx,
long timeoutMillis,
boolean profilingEnabled) |
OrderByStep(OOrderBy orderBy,
OCommandContext ctx,
long timeoutMillis,
boolean profilingEnabled) |
ORetryExecutionPlan(OCommandContext ctx) |
OScriptExecutionPlan(OCommandContext ctx) |
OSelectExecutionPlan(OCommandContext ctx) |
OSingleOpExecutionPlan(OCommandContext ctx,
OSimpleExecStatement stm) |
OUpdateExecutionPlan(OCommandContext ctx) |
ParallelExecStep(List<OInternalExecutionPlan> subExecuitonPlans,
OCommandContext ctx,
boolean profilingEnabled) |
ProjectionCalculationStep(OProjection projection,
OCommandContext ctx,
boolean profilingEnabled) |
RemoveEdgePointersStep(OCommandContext ctx,
boolean profilingEnabled) |
RemoveEmptyOptionalsStep(OCommandContext ctx,
boolean profilingEnabled) |
RemoveEmptyOptionalsStep(OCommandContext ctx,
OIdentifier cluster,
boolean profilingEnabled) |
RetryStep(List<OStatement> statements,
int retries,
List<OStatement> elseStatements,
Boolean elseFail,
OCommandContext ctx,
boolean enableProfiling) |
ReturnMatchElementsStep(OCommandContext context,
boolean profilingEnabled) |
ReturnMatchPathElementsStep(OCommandContext context,
boolean profilingEnabled) |
ReturnMatchPathsStep(OCommandContext context,
boolean profilingEnabled) |
ReturnMatchPatternsStep(OCommandContext context,
boolean profilingEnabled) |
ReturnStep(OSimpleExecStatement statement,
OCommandContext ctx,
boolean profilingEnabled) |
SaveElementStep(OCommandContext ctx,
boolean profilingEnabled) |
SaveElementStep(OCommandContext ctx,
OIdentifier cluster,
boolean profilingEnabled) |
ScriptLineStep(OInternalExecutionPlan nextPlan,
OCommandContext ctx,
boolean profilingEnabled) |
SetDocumentClassStep(OIdentifier targetClass,
OCommandContext ctx,
boolean profilingEnabled) |
SkipExecutionStep(OSkip skip,
OCommandContext ctx,
boolean profilingEnabled) |
SubQueryStep(OInternalExecutionPlan subExecutionPlan,
OCommandContext ctx,
OCommandContext subCtx,
boolean profilingEnabled)
executes a sub-query
|
TimeoutStep(OTimeout timeout,
OCommandContext ctx,
boolean profilingEnabled) |
UnwindStep(OUnwind unwind,
OCommandContext ctx,
boolean profilingEnabled) |
UnwrapPreviousValueStep(OCommandContext ctx,
boolean profilingEnabled) |
UpdateContentStep(OInputParameter inputParameter,
OCommandContext ctx,
boolean profilingEnabled) |
UpdateContentStep(OJson json,
OCommandContext ctx,
boolean profilingEnabled) |
UpdateEdgePointersStep(OCommandContext ctx,
boolean profilingEnabled) |
UpdateMergeStep(OJson json,
OCommandContext ctx,
boolean profilingEnabled) |
UpdateRemoveStep(List<OUpdateRemoveItem> items,
OCommandContext ctx,
boolean profilingEnabled) |
UpdateSetStep(List<OUpdateItem> updateItems,
OCommandContext ctx,
boolean profilingEnabled) |
UpsertStep(OFromClause target,
OWhereClause where,
OCommandContext ctx,
boolean profilingEnabled) |
WhileMatchStep(OCommandContext ctx,
OWhereClause condition,
OInternalExecutionPlan body,
boolean profilingEnabled) |
Modifier and Type | Field and Description |
---|---|
protected OCommandContext |
OSQLTarget.context |
protected OCommandContext |
OSQLPredicate.context |
Modifier and Type | Method and Description |
---|---|
Object |
OSQLPredicate.evaluate(OCommandContext iContext) |
protected Object |
OSQLFilterCondition.evaluate(OIdentifiable iCurrentRecord,
ODocument iCurrentResult,
Object iValue,
OCommandContext iContext,
boolean binaryEvaluation) |
Object |
OSQLPredicate.evaluate(OIdentifiable iRecord,
ODocument iCurrentResult,
OCommandContext iContext) |
Object |
OSQLFilterCondition.evaluate(OIdentifiable iCurrentRecord,
ODocument iCurrentResult,
OCommandContext iContext) |
Object |
OSQLFilter.evaluate(OIdentifiable iRecord,
ODocument iCurrentResult,
OCommandContext iContext) |
Object |
OSQLFilterItemFieldMultiAbstract.getValue(OIdentifiable iRecord,
Object iCurrentResult,
OCommandContext iContext) |
Object |
OSQLFilterItem.getValue(OIdentifiable iRecord,
Object iCurrentResult,
OCommandContext iContetx) |
Object |
OSQLFilterItemVariable.getValue(OIdentifiable iRecord,
Object iCurrentResult,
OCommandContext iContext) |
Object |
OSQLFilterItemField.getValue(OIdentifiable iRecord,
Object iCurrentResult,
OCommandContext iContext) |
Object |
OSQLFilterItemParameter.getValue(OIdentifiable iRecord,
Object iCurrentResult,
OCommandContext iContetx) |
Object |
OSQLFilterItemAbstract.transformValue(OIdentifiable iRecord,
OCommandContext iContext,
Object ioResult) |
Constructor and Description |
---|
OSQLFilter(String iText,
OCommandContext iContext,
String iFilterKeyword) |
OSQLTarget(String iText,
OCommandContext iContext) |
Modifier and Type | Method and Description |
---|---|
boolean |
OIndexableSQLFunction.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.
|
boolean |
OIndexableSQLFunction.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)
|
long |
OIndexableSQLFunction.estimate(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args)
estimates the number of entries returned by searchFromTarget() with these parameters
|
Object |
OSQLFunctionFiltered.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
Iterable<OIdentifiable> iPossibleResults,
OCommandContext iContext)
Process a record.
|
Object |
OSQLFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext)
Process a record.
|
Object |
OSQLFunctionRuntime.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
OCommandContext iContext)
Execute a function.
|
Object |
OSQLFunctionRuntime.getValue(OIdentifiable iRecord,
Object iCurrentResult,
OCommandContext iContext) |
Iterable<OIdentifiable> |
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 appears
|
boolean |
OIndexableSQLFunction.shouldExecuteAfterSearch(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args)
Checks if this function should be called even if the method
OIndexableSQLFunction.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. |
Modifier and Type | Method and Description |
---|---|
protected Object |
OSQLFunctionTraversedElement.evaluate(Object iThis,
Object[] iParams,
OCommandContext iContext,
String iClassName) |
Object |
OSQLFunctionTraversedVertex.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionDocument.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionList.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionLast.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionTraversedEdge.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionMap.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionDistinct.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionDifference.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionSet.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionSymmetricDifference.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionUnionAll.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionTraversedElement.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionIntersect.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionFirst.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLMethodMultiValue.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Modifier and Type | Method and Description |
---|---|
Object |
OSQLMethodAsDecimal.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodAsDate.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodAsDateTime.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodConvert.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodBeforeUpdate.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Modifier and Type | Method and Description |
---|---|
Object |
OSQLFunctionDistance.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Modifier and Type | Field and Description |
---|---|
protected OCommandContext |
OSQLFunctionHeuristicPathFinderAbstract.context |
protected OCommandContext |
OSQLFunctionPathFinder.context |
Modifier and Type | Method and Description |
---|---|
Object |
OSQLFunctionMoveFiltered.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParameters,
Iterable<OIdentifiable> iPossibleResults,
OCommandContext iContext) |
LinkedList<OVertex> |
OSQLFunctionAstar.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionMove.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParameters,
OCommandContext iContext) |
List<ORID> |
OSQLFunctionShortestPath.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
LinkedList<OVertex> |
OSQLFunctionDijkstra.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
protected LinkedList<OVertex> |
OSQLFunctionPathFinder.execute(OCommandContext iContext) |
protected double |
OSQLFunctionHeuristicPathFinderAbstract.getCustomHeuristicCost(String functionName,
String[] vertextAxisNames,
OVertex start,
OVertex goal,
OVertex current,
OVertex parent,
long depth,
double dFactor,
OCommandContext ctx) |
protected abstract double |
OSQLFunctionHeuristicPathFinderAbstract.getHeuristicCost(OVertex node,
OVertex parent,
OVertex target,
OCommandContext iContext) |
protected double |
OSQLFunctionAstar.getHeuristicCost(OVertex node,
OVertex parent,
OVertex target,
OCommandContext iContext) |
Modifier and Type | Method and Description |
---|---|
Object |
OSQLFunctionAbsoluteValue.execute(Object iThis,
OIdentifiable iRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionMax.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionDecimal.execute(Object iThis,
OIdentifiable iRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionInterval.execute(Object iThis,
OIdentifiable iRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionMin.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionAverage.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionEval.execute(Object iThis,
OIdentifiable iRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionSum.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Modifier and Type | Method and Description |
---|---|
Object |
OSQLFunctionIfNull.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionCount.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionIf.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionFormat.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionStrcmpci.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionEncode.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionUUID.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLStaticReflectiveFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionDate.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionThrowCME.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionDecode.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionIndexKeySize.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext context) |
Object |
OSQLFunctionCoalesce.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionSysdate.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLMethodExclude.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodInclude.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Modifier and Type | Method and Description |
---|---|
Object |
OSQLFunctionSequence.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Modifier and Type | Method and Description |
---|---|
Object |
OSQLFunctionVariance.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionMode.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionPercentile.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Modifier and Type | Method and Description |
---|---|
Object |
OSQLFunctionConcat.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSQLFunctionFormat.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] params,
OCommandContext iContext) |
Object |
OSQLMethodToJSON.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodReplace.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodAppend.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodFromJSON.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodLength.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodSubString.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodHash.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodRight.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Modifier and Type | Method and Description |
---|---|
Object |
OSQLMethodRuntime.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
OCommandContext iContext)
Execute a method.
|
Object |
OSQLMethodLeft.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodCharAt.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethod.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams)
Process a record.
|
Object |
OSQLMethodRuntime.getValue(OIdentifiable iRecord,
Object iCurrentResult,
OCommandContext iContext) |
Modifier and Type | Method and Description |
---|---|
Object |
OSQLMethodSplit.execute(Object iThis,
OIdentifiable iRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodValues.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodJavaType.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodRemoveAll.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodAsLong.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodIndexOf.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodAsString.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodField.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodFunctionDelegate.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodSize.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodPrefix.execute(Object iThis,
OIdentifiable iRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodTrim.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodLastIndexOf.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodToUpperCase.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodAsFloat.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodAsBoolean.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodAsSet.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodType.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodAsList.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodAsMap.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodKeys.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodToLowerCase.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodNormalize.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodFormat.execute(Object iThis,
OIdentifiable iRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodAsInteger.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodRemove.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Modifier and Type | Method and Description |
---|---|
Object |
OSQLMethodCurrent.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodReset.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Object |
OSQLMethodNext.execute(Object iThis,
OIdentifiable iCurrentRecord,
OCommandContext iContext,
Object ioResult,
Object[] iParams) |
Modifier and Type | Method and Description |
---|---|
boolean |
OQueryOperatorMajor.evaluate(OBinaryField iFirstField,
OBinaryField iSecondField,
OCommandContext iContext,
ODocumentSerializer serializer) |
boolean |
OQueryOperatorNotEquals2.evaluate(OBinaryField iFirstField,
OBinaryField iSecondField,
OCommandContext iContext,
ODocumentSerializer serializer) |
boolean |
OQueryOperatorNotEquals.evaluate(OBinaryField iFirstField,
OBinaryField iSecondField,
OCommandContext iContext,
ODocumentSerializer serializer) |
boolean |
OQueryOperatorMajorEquals.evaluate(OBinaryField iFirstField,
OBinaryField iSecondField,
OCommandContext iContext,
ODocumentSerializer serializer) |
boolean |
OQueryOperatorMinorEquals.evaluate(OBinaryField iFirstField,
OBinaryField iSecondField,
OCommandContext iContext,
ODocumentSerializer serializer) |
boolean |
OQueryOperatorEquals.evaluate(OBinaryField iFirstField,
OBinaryField iSecondField,
OCommandContext iContext,
ODocumentSerializer serializer) |
boolean |
OQueryOperatorEquality.evaluate(OBinaryField iFirstField,
OBinaryField iSecondField,
OCommandContext iContext,
ODocumentSerializer serializer) |
boolean |
OQueryOperatorMinor.evaluate(OBinaryField iFirstField,
OBinaryField iSecondField,
OCommandContext iContext,
ODocumentSerializer serializer) |
protected boolean |
OQueryOperatorIn.evaluateExpression(OIdentifiable iRecord,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext) |
protected boolean |
OQueryOperatorBetween.evaluateExpression(OIdentifiable iRecord,
OSQLFilterCondition condition,
Object left,
Object right,
OCommandContext iContext) |
protected boolean |
OQueryOperatorMatches.evaluateExpression(OIdentifiable iRecord,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext) |
protected boolean |
OQueryOperatorIs.evaluateExpression(OIdentifiable iRecord,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext) |
protected boolean |
OQueryOperatorTraverse.evaluateExpression(OIdentifiable iRecord,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext) |
protected boolean |
OQueryOperatorContainsValue.evaluateExpression(OIdentifiable iRecord,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext) |
protected boolean |
OQueryOperatorMajor.evaluateExpression(OIdentifiable iRecord,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext) |
protected boolean |
OQueryOperatorContainsKey.evaluateExpression(OIdentifiable iRecord,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext) |
protected boolean |
OQueryOperatorNotEquals2.evaluateExpression(OIdentifiable iRecord,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext) |
protected boolean |
OQueryOperatorNotEquals.evaluateExpression(OIdentifiable iRecord,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext) |
protected boolean |
OQueryOperatorMajorEquals.evaluateExpression(OIdentifiable iRecord,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext) |
protected boolean |
OQueryOperatorMinorEquals.evaluateExpression(OIdentifiable iRecord,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext) |
protected boolean |
OQueryOperatorEquals.evaluateExpression(OIdentifiable iRecord,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext) |
protected abstract boolean |
OQueryOperatorEquality.evaluateExpression(OIdentifiable iRecord,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext) |
protected boolean |
OQueryOperatorInstanceof.evaluateExpression(OIdentifiable iRecord,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext) |
protected boolean |
OQueryOperatorMinor.evaluateExpression(OIdentifiable iRecord,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext) |
protected boolean |
OQueryOperatorContains.evaluateExpression(OIdentifiable iRecord,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext) |
protected boolean |
OQueryOperatorContainsAll.evaluateExpression(OIdentifiable iRecord,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext) |
protected boolean |
OQueryOperatorLike.evaluateExpression(OIdentifiable iRecord,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext) |
Object |
OQueryOperatorAnd.evaluateRecord(OIdentifiable iRecord,
ODocument iCurrentResult,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext,
ODocumentSerializer serializer) |
abstract Object |
OQueryOperator.evaluateRecord(OIdentifiable iRecord,
ODocument iCurrentResult,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext,
ODocumentSerializer serializer) |
Object |
OQueryOperatorContainsText.evaluateRecord(OIdentifiable iRecord,
ODocument iCurrentResult,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext,
ODocumentSerializer serializer)
This is executed on non-indexed fields.
|
Object |
OQueryOperatorOr.evaluateRecord(OIdentifiable iRecord,
ODocument iCurrentResult,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext,
ODocumentSerializer serializer) |
Object |
OQueryOperatorEqualityNotNulls.evaluateRecord(OIdentifiable iRecord,
ODocument iCurrentResult,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext,
ODocumentSerializer serializer) |
Object |
OQueryOperatorNot.evaluateRecord(OIdentifiable iRecord,
ODocument iCurrentResult,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext,
ODocumentSerializer serializer) |
Object |
OQueryOperatorEquality.evaluateRecord(OIdentifiable iRecord,
ODocument iCurrentResult,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext,
ODocumentSerializer serializer) |
Object |
OQueryTargetOperator.evaluateRecord(OIdentifiable iRecord,
ODocument iCurrentResult,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext,
ODocumentSerializer serializer)
At run-time the evaluation per record must return always true since the recordset are filtered
at the beginning unless an operator can work in both modes.
|
Stream<ORawPair<Object,ORID>> |
OQueryOperator.executeIndexQuery(OCommandContext iContext,
OIndex index,
List<Object> keyParams,
boolean ascSortOrder)
Performs index query and returns index stream which presents subset of index data which
corresponds to result of execution of given operator.
|
Stream<ORawPair<Object,ORID>> |
OQueryOperatorIn.executeIndexQuery(OCommandContext iContext,
OIndex index,
List<Object> keyParams,
boolean ascSortOrder) |
Stream<ORawPair<Object,ORID>> |
OQueryOperatorBetween.executeIndexQuery(OCommandContext iContext,
OIndex index,
List<Object> keyParams,
boolean ascSortOrder) |
Stream<ORawPair<Object,ORID>> |
OQueryOperatorContainsText.executeIndexQuery(OCommandContext iContext,
OIndex index,
List<Object> keyParams,
boolean ascSortOrder) |
Stream<ORawPair<Object,ORID>> |
OQueryOperatorIs.executeIndexQuery(OCommandContext iContext,
OIndex index,
List<Object> keyParams,
boolean ascSortOrder) |
Stream<ORawPair<Object,ORID>> |
OQueryOperatorContainsValue.executeIndexQuery(OCommandContext iContext,
OIndex index,
List<Object> keyParams,
boolean ascSortOrder) |
Stream<ORawPair<Object,ORID>> |
OQueryOperatorMajor.executeIndexQuery(OCommandContext iContext,
OIndex index,
List<Object> keyParams,
boolean ascSortOrder) |
Stream<ORawPair<Object,ORID>> |
OQueryOperatorContainsKey.executeIndexQuery(OCommandContext iContext,
OIndex index,
List<Object> keyParams,
boolean ascSortOrder) |
Stream<ORawPair<Object,ORID>> |
OQueryOperatorMajorEquals.executeIndexQuery(OCommandContext iContext,
OIndex index,
List<Object> keyParams,
boolean ascSortOrder) |
Stream<ORawPair<Object,ORID>> |
OQueryOperatorMinorEquals.executeIndexQuery(OCommandContext iContext,
OIndex index,
List<Object> keyParams,
boolean ascSortOrder) |
Stream<ORawPair<Object,ORID>> |
OQueryOperatorEquals.executeIndexQuery(OCommandContext iContext,
OIndex index,
List<Object> keyParams,
boolean ascSortOrder) |
Stream<ORawPair<Object,ORID>> |
OQueryOperatorMinor.executeIndexQuery(OCommandContext iContext,
OIndex index,
List<Object> keyParams,
boolean ascSortOrder) |
Stream<ORawPair<Object,ORID>> |
OQueryOperatorContains.executeIndexQuery(OCommandContext iContext,
OIndex index,
List<Object> keyParams,
boolean ascSortOrder) |
OIndexSearchResult |
OQueryOperator.getOIndexSearchResult(OClass iSchemaClass,
OSQLFilterCondition iCondition,
List<OIndexSearchResult> iIndexSearchResults,
OCommandContext context) |
protected void |
OQueryOperator.updateProfiler(OCommandContext iContext,
OIndex index,
List<Object> keyParams,
OIndexDefinition indexDefinition) |
Modifier and Type | Method and Description |
---|---|
OCommandContext |
OMatchStatement.getContext() |
Modifier and Type | Method and Description |
---|---|
void |
OSuffixIdentifier.aggregate(Object value,
OCommandContext ctx) |
boolean |
OBinaryCondition.allowsIndexedFunctionExecutionOnTarget(OFromClause target,
OCommandContext context)
tests if current expression involves an indexed function AND that function can be used on this
target
|
boolean |
OValueExpression.allowsIndexedFunctionExecutionOnTarget(OFromClause target,
OCommandContext context,
OBinaryCompareOperator operator,
Object right) |
boolean |
OLevelZeroIdentifier.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 target
|
boolean |
OFunctionCall.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 target
|
boolean |
OBaseExpression.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 target
|
boolean |
OMathExpression.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 target
|
boolean |
OBaseIdentifier.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 target
|
boolean |
OExpression.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 target
|
Object |
ONestedProjection.apply(OExpression expression,
Object input,
OCommandContext ctx) |
void |
OUpdateItem.applyOperation(OResultInternal doc,
OIdentifier attrName,
Object rightValue,
OCommandContext ctx) |
void |
OSuffixIdentifier.applyRemove(Object currentValue,
OCommandContext ctx) |
void |
OModifier.applyRemove(Object currentValue,
OResultInternal originalRecord,
OCommandContext ctx) |
void |
OArrayRangeSelector.applyRemove(Object currentValue,
OResultInternal originalRecord,
OCommandContext ctx) |
void |
OArraySingleValuesSelector.applyRemove(Object currentValue,
OResultInternal originalRecord,
OCommandContext ctx) |
void |
OValueExpression.applyRemove(OResultInternal result,
OCommandContext ctx) |
void |
OParenthesisExpression.applyRemove(OResultInternal result,
OCommandContext ctx) |
void |
OBaseExpression.applyRemove(OResultInternal result,
OCommandContext ctx) |
void |
OMathExpression.applyRemove(OResultInternal result,
OCommandContext ctx) |
void |
OBaseIdentifier.applyRemove(OResultInternal result,
OCommandContext ctx) |
void |
OExpression.applyRemove(OResultInternal result,
OCommandContext ctx) |
void |
OUpdateRemoveItem.applyUpdate(OResultInternal result,
OCommandContext ctx) |
void |
OUpdateItem.applyUpdate(OResultInternal doc,
OCommandContext ctx) |
OLegacyResultSet |
OProjection.calculateExpand(OCommandContext iContext,
OResult iRecord) |
OResult |
OProjection.calculateSingle(OCommandContext iContext,
OResult iRecord) |
boolean |
OBinaryCondition.canExecuteIndexedFunctionWithoutIndex(OFromClause target,
OCommandContext context)
tests if current expression involves an indexed funciton AND that function can also be executed
without using the index
|
boolean |
OValueExpression.canExecuteIndexedFunctionWithoutIndex(OFromClause target,
OCommandContext context,
OBinaryCompareOperator operator,
Object right) |
boolean |
OLevelZeroIdentifier.canExecuteIndexedFunctionWithoutIndex(OFromClause target,
OCommandContext context,
OBinaryCompareOperator operator,
Object right)
tests if current expression is an indexed funciton AND that function can also be executed
without using the index
|
boolean |
OFunctionCall.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 index
|
boolean |
OBaseExpression.canExecuteIndexedFunctionWithoutIndex(OFromClause target,
OCommandContext context,
OBinaryCompareOperator operator,
Object right)
tests if current expression is an indexed funciton AND that function can also be executed
without using the index
|
boolean |
OMathExpression.canExecuteIndexedFunctionWithoutIndex(OFromClause target,
OCommandContext context,
OBinaryCompareOperator operator,
Object right)
tests if current expression is an indexed funciton AND that function can also be executed
without using the index
|
boolean |
OBaseIdentifier.canExecuteIndexedFunctionWithoutIndex(OFromClause target,
OCommandContext context,
OBinaryCompareOperator operator,
Object right)
tests if current expression is an indexed funciton AND that function can also be executed
without using the index
|
boolean |
OExpression.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 index
|
int |
OOrderByItem.compare(OResult a,
OResult b,
OCommandContext ctx) |
int |
OOrderBy.compare(OResult a,
OResult b,
OCommandContext ctx) |
static Object |
OUpdateItem.convertToPropertyType(OResultInternal res,
OIdentifier attrName,
Object newValue,
OCommandContext ctx) |
OInternalExecutionPlan |
OStatement.createExecutionPlan(OCommandContext ctx)
creates an execution plan for current statement, with profiling disabled
|
OInsertExecutionPlan |
OInsertStatement.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OInternalExecutionPlan |
OProfileStatement.createExecutionPlan(OCommandContext ctx,
boolean profile) |
OUpdateExecutionPlan |
OWhileBlock.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OInternalExecutionPlan |
OStatement.createExecutionPlan(OCommandContext ctx,
boolean profile)
creates an execution plan for current statement
|
OInternalExecutionPlan |
ODeleteEdgeStatement.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OInternalExecutionPlan |
OSimpleExecStatement.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OInsertExecutionPlan |
OCreateEdgeStatement.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OInternalExecutionPlan |
ODDLStatement.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OInternalExecutionPlan |
OMatchStatement.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OInternalExecutionPlan |
OSelectStatement.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OIfExecutionPlan |
OIfStatement.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OInternalExecutionPlan |
OExplainStatement.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OUpdateExecutionPlan |
OForEachBlock.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
ODeleteExecutionPlan |
ODeleteVertexStatement.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OInternalExecutionPlan |
OCreateVertexStatement.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OUpdateExecutionPlan |
OUpdateStatement.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OInternalExecutionPlan |
OTraverseStatement.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
ODeleteExecutionPlan |
ODeleteStatement.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OUpdateExecutionPlan |
OMoveVertexStatement.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OInternalExecutionPlan |
OFindReferencesStatement.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OUpdateExecutionPlan |
OUpdateEdgeStatement.createExecutionPlan(OCommandContext ctx,
boolean enableProfiling) |
OInternalExecutionPlan |
OStatement.createExecutionPlanNoCache(OCommandContext ctx,
boolean profile) |
OInternalExecutionPlan |
ODeleteEdgeStatement.createExecutionPlanNoCache(OCommandContext ctx,
boolean enableProfiling) |
OInsertExecutionPlan |
OCreateEdgeStatement.createExecutionPlanNoCache(OCommandContext ctx,
boolean enableProfiling) |
OInternalExecutionPlan |
OSelectStatement.createExecutionPlanNoCache(OCommandContext ctx,
boolean enableProfiling) |
long |
OWhereClause.estimate(OClass oClass,
long threshold,
OCommandContext ctx)
estimates how many items of this class will be returned applying this filter
|
long |
OBinaryCondition.estimateIndexed(OFromClause target,
OCommandContext context) |
long |
OLevelZeroIdentifier.estimateIndexedFunction(OFromClause target,
OCommandContext context,
OBinaryCompareOperator operator,
Object right) |
long |
OFunctionCall.estimateIndexedFunction(OFromClause target,
OCommandContext ctx,
OBinaryCompareOperator operator,
Object rightValue) |
long |
OBaseExpression.estimateIndexedFunction(OFromClause target,
OCommandContext context,
OBinaryCompareOperator operator,
Object right) |
long |
OMathExpression.estimateIndexedFunction(OFromClause target,
OCommandContext context,
OBinaryCompareOperator operator,
Object right) |
long |
OBaseIdentifier.estimateIndexedFunction(OFromClause target,
OCommandContext context,
OBinaryCompareOperator operator,
Object right) |
long |
OExpression.estimateIndexedFunction(OFromClause target,
OCommandContext context,
OBinaryCompareOperator operator,
Object right) |
boolean |
OOrBlock.evaluate(Object currentRecord,
OCommandContext ctx) |
Integer |
OBatch.evaluate(OCommandContext ctx) |
Object |
ORecordAttribute.evaluate(OElement iCurrentRecord,
OCommandContext ctx) |
boolean |
OAndBlock.evaluate(OIdentifiable currentRecord,
OCommandContext ctx) |
boolean |
OOrBlock.evaluate(OIdentifiable currentRecord,
OCommandContext ctx) |
boolean |
OInCondition.evaluate(OIdentifiable currentRecord,
OCommandContext ctx) |
boolean |
OInstanceofCondition.evaluate(OIdentifiable currentRecord,
OCommandContext ctx) |
boolean |
OMatchesCondition.evaluate(OIdentifiable currentRecord,
OCommandContext ctx) |
boolean |
OBinaryCondition.evaluate(OIdentifiable currentRecord,
OCommandContext ctx) |
boolean |
OIsNullCondition.evaluate(OIdentifiable currentRecord,
OCommandContext ctx) |
boolean |
ONotInCondition.evaluate(OIdentifiable currentRecord,
OCommandContext ctx) |
boolean |
OIsDefinedCondition.evaluate(OIdentifiable currentRecord,
OCommandContext ctx) |
abstract boolean |
OBooleanExpression.evaluate(OIdentifiable currentRecord,
OCommandContext ctx) |
boolean |
OIsNotDefinedCondition.evaluate(OIdentifiable currentRecord,
OCommandContext ctx) |
boolean |
OIsNotNullCondition.evaluate(OIdentifiable currentRecord,
OCommandContext ctx) |
boolean |
OContainsAnyCondition.evaluate(OIdentifiable currentRecord,
OCommandContext ctx) |
boolean |
OContainsTextCondition.evaluate(OIdentifiable currentRecord,
OCommandContext ctx) |
boolean |
OContainsAllCondition.evaluate(OIdentifiable currentRecord,
OCommandContext ctx) |
boolean |
OContainsValueCondition.evaluate(OIdentifiable currentRecord,
OCommandContext ctx) |
boolean |
ONotBlock.evaluate(OIdentifiable currentRecord,
OCommandContext ctx) |
boolean |
OBetweenCondition.evaluate(OIdentifiable currentRecord,
OCommandContext ctx) |
boolean |
OParenthesisBlock.evaluate(OIdentifiable currentRecord,
OCommandContext ctx) |
boolean |
OContainsCondition.evaluate(OIdentifiable currentRecord,
OCommandContext ctx) |
boolean |
OAndBlock.evaluate(OResult currentRecord,
OCommandContext ctx) |
boolean |
OOrBlock.evaluate(OResult currentRecord,
OCommandContext ctx) |
boolean |
OInCondition.evaluate(OResult currentRecord,
OCommandContext ctx) |
boolean |
OInstanceofCondition.evaluate(OResult currentRecord,
OCommandContext ctx) |
boolean |
OMatchesCondition.evaluate(OResult currentRecord,
OCommandContext ctx) |
boolean |
OBinaryCondition.evaluate(OResult currentRecord,
OCommandContext ctx) |
boolean |
OIsNullCondition.evaluate(OResult currentRecord,
OCommandContext ctx) |
Object |
ORecordAttribute.evaluate(OResult iCurrentRecord,
OCommandContext ctx) |
boolean |
ONotInCondition.evaluate(OResult currentRecord,
OCommandContext ctx) |
boolean |
OIsDefinedCondition.evaluate(OResult currentRecord,
OCommandContext ctx) |
abstract boolean |
OBooleanExpression.evaluate(OResult currentRecord,
OCommandContext ctx) |
boolean |
OIsNotDefinedCondition.evaluate(OResult currentRecord,
OCommandContext ctx) |
boolean |
OIsNotNullCondition.evaluate(OResult currentRecord,
OCommandContext ctx) |
boolean |
OContainsAnyCondition.evaluate(OResult currentRecord,
OCommandContext ctx) |
boolean |
OContainsTextCondition.evaluate(OResult currentRecord,
OCommandContext ctx) |
boolean |
OContainsAllCondition.evaluate(OResult currentRecord,
OCommandContext ctx) |
boolean |
OContainsValueCondition.evaluate(OResult currentRecord,
OCommandContext ctx) |
boolean |
ONotBlock.evaluate(OResult currentRecord,
OCommandContext ctx) |
boolean |
OBetweenCondition.evaluate(OResult currentRecord,
OCommandContext ctx) |
boolean |
OParenthesisBlock.evaluate(OResult currentRecord,
OCommandContext ctx) |
boolean |
OContainsCondition.evaluate(OResult currentRecord,
OCommandContext ctx) |
Object |
OInCondition.evaluateLeft(OIdentifiable currentRecord,
OCommandContext ctx) |
Object |
OInCondition.evaluateLeft(OResult currentRecord,
OCommandContext ctx) |
Object |
OInCondition.evaluateRight(OIdentifiable currentRecord,
OCommandContext ctx) |
Object |
ORightBinaryCondition.evaluateRight(OIdentifiable currentRecord,
OCommandContext ctx) |
Object |
OInCondition.evaluateRight(OResult currentRecord,
OCommandContext ctx) |
Object |
ORightBinaryCondition.evaluateRight(OResult currentRecord,
OCommandContext ctx) |
Object |
OSuffixIdentifier.execute(Iterable iterable,
OCommandContext ctx) |
Object |
OSuffixIdentifier.execute(Iterator iterator,
OCommandContext ctx) |
Object |
OSuffixIdentifier.execute(Map iCurrentRecord,
OCommandContext ctx) |
Object |
OMethodCall.execute(Object targetObjects,
Iterable<OIdentifiable> iPossibleResults,
OCommandContext ctx) |
Object |
OSuffixIdentifier.execute(Object currentValue,
OCommandContext ctx) |
Object |
OFunctionCall.execute(Object targetObjects,
OCommandContext ctx) |
Object |
OMethodCall.execute(Object targetObjects,
OCommandContext ctx) |
Object |
OSuffixIdentifier.execute(OCommandContext iCurrentRecord) |
OResultSet |
OStatement.execute(ODatabase db,
Map args,
OCommandContext parentContext) |
OResultSet |
OInsertStatement.execute(ODatabase db,
Map params,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OProfileStatement.execute(ODatabase db,
Map args,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OHaRemoveServerStatement.execute(ODatabase db,
Map args,
OCommandContext parentContext,
boolean usePlanCache) |
OResultSet |
OWhileBlock.execute(ODatabase db,
Map params,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OStatement.execute(ODatabase db,
Map args,
OCommandContext parentContext,
boolean usePlanCache) |
OResultSet |
ODeleteEdgeStatement.execute(ODatabase db,
Map params,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OSimpleExecStatement.execute(ODatabase db,
Map params,
OCommandContext parentContext,
boolean usePlanCache) |
OResultSet |
OCreateEdgeStatement.execute(ODatabase db,
Map params,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
ODDLStatement.execute(ODatabase db,
Map params,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OMatchStatement.execute(ODatabase db,
Map params,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OSelectStatement.execute(ODatabase db,
Map params,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OIfStatement.execute(ODatabase db,
Map params,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OExplainStatement.execute(ODatabase db,
Map args,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OForEachBlock.execute(ODatabase db,
Map params,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
ODeleteVertexStatement.execute(ODatabase db,
Map params,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OCreateVertexStatement.execute(ODatabase db,
Map params,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OUpdateStatement.execute(ODatabase db,
Map params,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OTraverseStatement.execute(ODatabase db,
Map params,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
ODeleteStatement.execute(ODatabase db,
Map params,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OMoveVertexStatement.execute(ODatabase db,
Map params,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OFindReferencesStatement.execute(ODatabase db,
Map params,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OStatement.execute(ODatabase db,
Object[] args,
OCommandContext parentContext) |
OResultSet |
OInsertStatement.execute(ODatabase db,
Object[] args,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OProfileStatement.execute(ODatabase db,
Object[] args,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OHaRemoveServerStatement.execute(ODatabase db,
Object[] args,
OCommandContext parentContext,
boolean usePlanCache) |
OResultSet |
OWhileBlock.execute(ODatabase db,
Object[] args,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OStatement.execute(ODatabase db,
Object[] args,
OCommandContext parentContext,
boolean usePlanCache) |
OResultSet |
ODeleteEdgeStatement.execute(ODatabase db,
Object[] args,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OSimpleExecStatement.execute(ODatabase db,
Object[] args,
OCommandContext parentContext,
boolean usePlanCache) |
OResultSet |
OCreateEdgeStatement.execute(ODatabase db,
Object[] args,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
ODDLStatement.execute(ODatabase db,
Object[] args,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OMatchStatement.execute(ODatabase db,
Object[] args,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OSelectStatement.execute(ODatabase db,
Object[] args,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OIfStatement.execute(ODatabase db,
Object[] args,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OExplainStatement.execute(ODatabase db,
Object[] args,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OForEachBlock.execute(ODatabase db,
Object[] args,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
ODeleteVertexStatement.execute(ODatabase db,
Object[] args,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OCreateVertexStatement.execute(ODatabase db,
Object[] args,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OUpdateStatement.execute(ODatabase db,
Object[] args,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OTraverseStatement.execute(ODatabase db,
Object[] args,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
ODeleteStatement.execute(ODatabase db,
Object[] args,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OMoveVertexStatement.execute(ODatabase db,
Object[] args,
OCommandContext parentCtx,
boolean usePlanCache) |
OResultSet |
OFindReferencesStatement.execute(ODatabase db,
Object[] args,
OCommandContext parentCtx,
boolean usePlanCache) |
Object |
OModifier.execute(OIdentifiable iCurrentRecord,
Object result,
OCommandContext ctx) |
Object |
OArrayRangeSelector.execute(OIdentifiable iCurrentRecord,
Object result,
OCommandContext ctx) |
Object |
ORightBinaryCondition.execute(OIdentifiable iCurrentRecord,
Object elementToFilter,
OCommandContext ctx) |
Object |
OArraySingleValuesSelector.execute(OIdentifiable iCurrentRecord,
Object iResult,
OCommandContext ctx) |
Object |
OValueExpression.execute(OIdentifiable iCurrentRecord,
OCommandContext ctx) |
Object |
OArrayConcatExpression.execute(OIdentifiable iCurrentRecord,
OCommandContext ctx) |
Object |
OSuffixIdentifier.execute(OIdentifiable iCurrentRecord,
OCommandContext ctx) |
Object |
OLevelZeroIdentifier.execute(OIdentifiable iCurrentRecord,
OCommandContext ctx) |
Object |
OProjectionItem.execute(OIdentifiable iCurrentRecord,
OCommandContext ctx) |
Object |
OParenthesisExpression.execute(OIdentifiable iCurrentRecord,
OCommandContext ctx) |
Object |
OBaseExpression.execute(OIdentifiable iCurrentRecord,
OCommandContext ctx) |
Object |
OMathExpression.execute(OIdentifiable iCurrentRecord,
OCommandContext ctx) |
Object |
OBaseIdentifier.execute(OIdentifiable iCurrentRecord,
OCommandContext ctx) |
Object |
OExpression.execute(OIdentifiable iCurrentRecord,
OCommandContext ctx) |
Object |
OCollection.execute(OIdentifiable iCurrentRecord,
OCommandContext ctx) |
Object |
OModifier.execute(OResult iCurrentRecord,
Object result,
OCommandContext ctx) |
Object |
OArrayRangeSelector.execute(OResult iCurrentRecord,
Object result,
OCommandContext ctx) |
Object |
ORightBinaryCondition.execute(OResult iCurrentRecord,
Object elementToFilter,
OCommandContext ctx) |
Object |
OArraySingleValuesSelector.execute(OResult iCurrentRecord,
Object iResult,
OCommandContext ctx) |
Object |
OValueExpression.execute(OResult iCurrentRecord,
OCommandContext ctx) |
Object |
OArrayConcatExpression.execute(OResult iCurrentRecord,
OCommandContext ctx) |
Object |
OSuffixIdentifier.execute(OResult iCurrentRecord,
OCommandContext ctx) |
Object |
OLevelZeroIdentifier.execute(OResult iCurrentRecord,
OCommandContext ctx) |
Object |
OTraverseProjectionItem.execute(OResult iCurrentRecord,
OCommandContext ctx) |
Object |
OProjectionItem.execute(OResult iCurrentRecord,
OCommandContext ctx) |
Object |
OParenthesisExpression.execute(OResult iCurrentRecord,
OCommandContext ctx) |
Object |
OBaseExpression.execute(OResult iCurrentRecord,
OCommandContext ctx) |
Object |
OMathExpression.execute(OResult iCurrentRecord,
OCommandContext ctx) |
Object |
OBaseIdentifier.execute(OResult iCurrentRecord,
OCommandContext ctx) |
Object |
OExpression.execute(OResult iCurrentRecord,
OCommandContext ctx) |
Object |
OCollection.execute(OResult iCurrentRecord,
OCommandContext ctx) |
Object |
OProfileStorageStatement.execute(OSQLAsynchQuery<ODocument> request,
OCommandContext context,
OProgressListener progressListener) |
Object |
OStatement.execute(OSQLAsynchQuery<ODocument> request,
OCommandContext context,
OProgressListener progressListener) |
Object |
OMatchStatement.execute(OSQLAsynchQuery<ODocument> request,
OCommandContext context,
OProgressListener progressListener)
executes the match statement.
|
OResultSet |
OCreateViewStatement.executeDDL(OCommandContext ctx) |
OResultSet |
ODropClusterStatement.executeDDL(OCommandContext ctx) |
OResultSet |
OCreateClusterStatement.executeDDL(OCommandContext ctx) |
OResultSet |
OCreateClassStatement.executeDDL(OCommandContext ctx) |
OResultSet |
OAlterDatabaseStatement.executeDDL(OCommandContext ctx) |
OResultSet |
OAlterPropertyStatement.executeDDL(OCommandContext ctx) |
OResultSet |
OAlterClusterStatement.executeDDL(OCommandContext ctx) |
OResultSet |
OTruncateClusterStatement.executeDDL(OCommandContext ctx) |
OResultSet |
OTruncateClassStatement.executeDDL(OCommandContext ctx) |
OResultSet |
OCreateIndexStatement.executeDDL(OCommandContext ctx) |
OResultSet |
OAlterClassStatement.executeDDL(OCommandContext ctx) |
abstract OResultSet |
ODDLStatement.executeDDL(OCommandContext ctx) |
OResultSet |
ODropPropertyStatement.executeDDL(OCommandContext ctx) |
OResultSet |
OCreatePropertyStatement.executeDDL(OCommandContext ctx) |
OResultSet |
OAlterSequenceStatement.executeDDL(OCommandContext ctx) |
OResultSet |
ODropClassStatement.executeDDL(OCommandContext ctx) |
OResultSet |
ODropSequenceStatement.executeDDL(OCommandContext ctx) |
OResultSet |
ODropIndexStatement.executeDDL(OCommandContext ctx) |
OResultSet |
ODropViewStatement.executeDDL(OCommandContext ctx) |
Iterable<OIdentifiable> |
OBinaryCondition.executeIndexedFunction(OFromClause target,
OCommandContext context) |
Iterable<OIdentifiable> |
OLevelZeroIdentifier.executeIndexedFunction(OFromClause target,
OCommandContext context,
OBinaryCompareOperator operator,
Object right) |
Iterable<OIdentifiable> |
OFunctionCall.executeIndexedFunction(OFromClause target,
OCommandContext ctx,
OBinaryCompareOperator operator,
Object rightValue)
see OIndexableSQLFunction.searchFromTarget()
|
Iterable<OIdentifiable> |
OBaseExpression.executeIndexedFunction(OFromClause target,
OCommandContext context,
OBinaryCompareOperator operator,
Object right) |
Iterable<OIdentifiable> |
OMathExpression.executeIndexedFunction(OFromClause target,
OCommandContext context,
OBinaryCompareOperator operator,
Object right) |
Iterable<OIdentifiable> |
OBaseIdentifier.executeIndexedFunction(OFromClause target,
OCommandContext context,
OBinaryCompareOperator operator,
Object right) |
Iterable<OIdentifiable> |
OExpression.executeIndexedFunction(OFromClause target,
OCommandContext context,
OBinaryCompareOperator operator,
Object right) |
boolean |
OBinaryCondition.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.
|
boolean |
OValueExpression.executeIndexedFunctionAfterIndexSearch(OFromClause target,
OCommandContext context,
OBinaryCompareOperator operator,
Object right) |
boolean |
OLevelZeroIdentifier.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.
|
boolean |
OFunctionCall.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.
|
boolean |
OBaseExpression.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.
|
boolean |
OMathExpression.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.
|
boolean |
OBaseIdentifier.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.
|
boolean |
OExpression.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.
|
protected static Object |
OInCondition.executeQuery(OSelectStatement rightStatement,
OCommandContext ctx) |
Object |
OMethodCall.executeReverse(Object targetObjects,
OCommandContext ctx) |
OResultSet |
OCommitStatement.executeSimple(OCommandContext ctx) |
OResultSet |
OConsoleStatement.executeSimple(OCommandContext ctx) |
OResultSet |
OOptimizeDatabaseStatement.executeSimple(OCommandContext ctx) |
OResultSet |
OProfileStorageStatement.executeSimple(OCommandContext ctx) |
OResultSet |
OHaStatusStatement.executeSimple(OCommandContext ctx) |
OResultSet |
ORollbackStatement.executeSimple(OCommandContext ctx) |
OResultSet |
OBeginStatement.executeSimple(OCommandContext ctx) |
OResultSet |
OCreateLinkStatement.executeSimple(OCommandContext ctx) |
OResultSet |
OCreateSecurityPolicyStatement.executeSimple(OCommandContext ctx) |
OResultSet |
ORevokeStatement.executeSimple(OCommandContext ctx) |
OResultSet |
OCreateUserStatement.executeSimple(OCommandContext ctx) |
abstract OResultSet |
OSimpleExecStatement.executeSimple(OCommandContext ctx) |
OResultSet |
OSleepStatement.executeSimple(OCommandContext ctx) |
OResultSet |
OLetStatement.executeSimple(OCommandContext ctx) |
OResultSet |
OAlterRoleStatement.executeSimple(OCommandContext ctx) |
OResultSet |
OHaSetStatement.executeSimple(OCommandContext ctx) |
OResultSet |
OHaSyncDatabaseStatement.executeSimple(OCommandContext ctx) |
OResultSet |
OReturnStatement.executeSimple(OCommandContext ctx) |
OResultSet |
ODropUserStatement.executeSimple(OCommandContext ctx) |
OResultSet |
OGrantStatement.executeSimple(OCommandContext ctx) |
OResultSet |
OExpressionStatement.executeSimple(OCommandContext ctx) |
OResultSet |
OAlterSecurityPolicyStatement.executeSimple(OCommandContext ctx) |
OResultSet |
OCreateSequenceStatement.executeSimple(OCommandContext ctx) |
OResultSet |
OHaSyncClusterStatement.executeSimple(OCommandContext ctx) |
OResultSet |
ORebuildIndexStatement.executeSimple(OCommandContext ctx) |
OResultSet |
OCreateFunctionStatement.executeSimple(OCommandContext ctx) |
OResultSet |
OTruncateRecordStatement.executeSimple(OCommandContext ctx) |
Iterable<OIdentifiable> |
OMatchPathItem.executeTraversal(OMatchStatement.MatchContext matchContext,
OCommandContext iCommandContext,
OIdentifiable startingPoint,
int depth) |
Object |
ONestedProjectionItem.expand(OExpression expression,
String name,
Object value,
OCommandContext ctx,
int recursion) |
Iterable |
OWhereClause.fetchFromIndexes(OClass oClass,
OCommandContext ctx) |
static OExecutionPlan |
OExecutionPlanCache.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't
|
AggregationContext |
OValueExpression.getAggregationContext(OCommandContext ctx) |
AggregationContext |
OArrayConcatExpression.getAggregationContext(OCommandContext ctx) |
AggregationContext |
OSuffixIdentifier.getAggregationContext(OCommandContext ctx) |
AggregationContext |
OLevelZeroIdentifier.getAggregationContext(OCommandContext ctx) |
AggregationContext |
OFunctionCall.getAggregationContext(OCommandContext ctx) |
AggregationContext |
OProjectionItem.getAggregationContext(OCommandContext ctx) |
AggregationContext |
OBaseExpression.getAggregationContext(OCommandContext ctx) |
AggregationContext |
OMathExpression.getAggregationContext(OCommandContext ctx) |
AggregationContext |
OBaseIdentifier.getAggregationContext(OCommandContext ctx) |
AggregationContext |
OExpression.getAggregationContext(OCommandContext ctx) |
String |
OMatchFilter.getClassName(OCommandContext context) |
String |
OMatchFilter.getClusterName(OCommandContext context) |
OCollate |
OValueExpression.getCollate(OResult currentRecord,
OCommandContext ctx) |
OCollate |
OSuffixIdentifier.getCollate(OResult currentRecord,
OCommandContext ctx) |
OCollate |
OBaseExpression.getCollate(OResult currentRecord,
OCommandContext ctx) |
OCollate |
OMathExpression.getCollate(OResult currentRecord,
OCommandContext ctx) |
OCollate |
OBaseIdentifier.getCollate(OResult currentRecord,
OCommandContext ctx) |
OCollate |
OExpression.getCollate(OResult currentRecord,
OCommandContext ctx) |
OExecutionPlan |
OExecutionPlanCache.getInternal(String statement,
OCommandContext ctx,
ODatabaseDocumentInternal db) |
ORid |
OMatchFilter.getRid(OCommandContext context) |
int |
OSkip.getValue(OCommandContext ctx) |
int |
OLimit.getValue(OCommandContext ctx) |
Integer |
OArrayNumberSelector.getValue(OIdentifiable iCurrentRecord,
Object iResult,
OCommandContext ctx) |
Object |
OArraySelector.getValue(OIdentifiable iCurrentRecord,
Object iResult,
OCommandContext ctx) |
Integer |
OArrayNumberSelector.getValue(OResult iCurrentRecord,
Object iResult,
OCommandContext ctx) |
Object |
OArraySelector.getValue(OResult iCurrentRecord,
Object iResult,
OCommandContext ctx) |
OScriptExecutionPlan |
WhileStep.initPlan(OCommandContext ctx) |
boolean |
OArrayConcatExpression.isEarlyCalculated(OCommandContext ctx) |
boolean |
OSuffixIdentifier.isEarlyCalculated(OCommandContext ctx) |
boolean |
OLevelZeroIdentifier.isEarlyCalculated(OCommandContext ctx) |
boolean |
OFunctionCall.isEarlyCalculated(OCommandContext ctx) |
boolean |
OParenthesisExpression.isEarlyCalculated(OCommandContext ctx) |
boolean |
OIdentifier.isEarlyCalculated(OCommandContext ctx) |
boolean |
OBaseExpression.isEarlyCalculated(OCommandContext ctx) |
boolean |
OMathExpression.isEarlyCalculated(OCommandContext ctx) |
boolean |
OBaseIdentifier.isEarlyCalculated(OCommandContext ctx) |
boolean |
OExpression.isEarlyCalculated(OCommandContext ctx) |
boolean |
OCollection.isEarlyCalculated(OCommandContext ctx) |
boolean |
OModifier.isIndexChain(OCommandContext ctx,
OClass clazz) |
boolean |
OBaseExpression.isIndexChain(OCommandContext ctx,
OClass clazz) |
boolean |
OMathExpression.isIndexChain(OCommandContext ctx,
OClass clazz) |
boolean |
OBaseIdentifier.isIndexChain(OCommandContext ctx,
OClass clazz) |
boolean |
OExpression.isIndexChain(OCommandContext ctx,
OClass clazz) |
boolean |
OWhereClause.matchesFilters(OIdentifiable currentRecord,
OCommandContext ctx) |
boolean |
OWhereClause.matchesFilters(OResult currentRecord,
OCommandContext ctx) |
OBooleanExpression |
OAndBlock.rewriteIndexChainsAsSubqueries(OCommandContext ctx,
OClass clazz) |
OBooleanExpression |
OOrBlock.rewriteIndexChainsAsSubqueries(OCommandContext ctx,
OClass clazz) |
OBooleanExpression |
OBinaryCondition.rewriteIndexChainsAsSubqueries(OCommandContext ctx,
OClass clazz) |
OBooleanExpression |
OBooleanExpression.rewriteIndexChainsAsSubqueries(OCommandContext ctx,
OClass clazz) |
OBooleanExpression |
ONotBlock.rewriteIndexChainsAsSubqueries(OCommandContext ctx,
OClass clazz) |
void |
OMatchStatement.setContext(OCommandContext context) |
Object |
OCreatePropertyAttributeStatement.setOnProperty(OPropertyImpl internalProp,
OCommandContext ctx) |
void |
OArraySelector.setValue(List target,
int idx,
Object value,
OCommandContext ctx) |
void |
OArrayRangeSelector.setValue(List target,
Object value,
OCommandContext ctx) |
void |
OArraySelector.setValue(Map target,
Object idx,
Object value,
OCommandContext ctx) |
void |
OSuffixIdentifier.setValue(Map target,
Object value,
OCommandContext ctx) |
void |
OArrayRangeSelector.setValue(Map target,
Object value,
OCommandContext ctx) |
void |
OSuffixIdentifier.setValue(Object target,
Object value,
OCommandContext ctx) |
void |
OArrayRangeSelector.setValue(Object target,
Object value,
OCommandContext ctx) |
void |
OSuffixIdentifier.setValue(OIdentifiable target,
Object value,
OCommandContext ctx) |
protected void |
OModifier.setValue(OResult currentRecord,
Object target,
Object value,
OCommandContext ctx) |
void |
OArraySelector.setValue(OResult currentRecord,
Object target,
Object value,
OCommandContext ctx) |
void |
OArraySingleValuesSelector.setValue(OResult currentRecord,
Object target,
Object value,
OCommandContext ctx) |
void |
OSuffixIdentifier.setValue(OResult target,
Object value,
OCommandContext ctx) |
void |
OArraySelector.setValue(Set target,
int idx,
Object value,
OCommandContext ctx) |
void |
OArrayRangeSelector.setValue(Set target,
Object value,
OCommandContext ctx) |
SimpleNode |
OLevelZeroIdentifier.splitForAggregation(AggregateProjectionSplit aggregateProj,
OCommandContext ctx) |
OJsonItem |
OJsonItem.splitForAggregation(AggregateProjectionSplit aggregateSplit,
OCommandContext ctx) |
SimpleNode |
OFunctionCall.splitForAggregation(AggregateProjectionSplit aggregateProj,
OCommandContext ctx) |
OProjectionItem |
OProjectionItem.splitForAggregation(AggregateProjectionSplit aggregateSplit,
OCommandContext ctx)
INTERNAL USE ONLY this has to be invoked ONLY if the item is aggregate!!!
|
SimpleNode |
OParenthesisExpression.splitForAggregation(AggregateProjectionSplit aggregateProj,
OCommandContext ctx) |
SimpleNode |
OBaseExpression.splitForAggregation(AggregateProjectionSplit aggregateProj,
OCommandContext ctx) |
SimpleNode |
OMathExpression.splitForAggregation(AggregateProjectionSplit aggregateProj,
OCommandContext ctx) |
SimpleNode |
OBaseIdentifier.splitForAggregation(AggregateProjectionSplit aggregateProj,
OCommandContext ctx) |
OJson |
OJson.splitForAggregation(AggregateProjectionSplit aggregateSplit,
OCommandContext ctx) |
OExpression |
OExpression.splitForAggregation(AggregateProjectionSplit aggregateSplit,
OCommandContext ctx) |
OCollection |
OCollection.splitForAggregation(AggregateProjectionSplit aggregateProj,
OCommandContext ctx) |
OResultSet |
WhileStep.syncPull(OCommandContext ctx,
int nRecords) |
ODocument |
OJson.toDocument(OIdentifiable source,
OCommandContext ctx) |
Map<String,Object> |
OJson.toMap(OIdentifiable source,
OCommandContext ctx) |
Map<String,Object> |
OJson.toMap(OResult source,
OCommandContext ctx) |
Object |
OJson.toObjectDetermineType(OResult source,
OCommandContext ctx)
choosing return type is based on existence of @class and @type field in JSON
|
ORecordId |
ORid.toRecordId(OIdentifiable target,
OCommandContext ctx) |
ORecordId |
ORid.toRecordId(OResult target,
OCommandContext ctx) |
protected Iterable<OIdentifiable> |
OMatchPathItemFirst.traversePatternEdge(OMatchStatement.MatchContext matchContext,
OIdentifiable startingPoint,
OCommandContext iCommandContext) |
protected Iterable<OIdentifiable> |
OMatchPathItem.traversePatternEdge(OMatchStatement.MatchContext matchContext,
OIdentifiable startingPoint,
OCommandContext iCommandContext) |
protected Iterable<OIdentifiable> |
OMultiMatchPathItem.traversePatternEdge(OMatchStatement.MatchContext matchContext,
OIdentifiable startingPoint,
OCommandContext iCommandContext) |
protected Iterable<OIdentifiable> |
OFieldMatchPathItem.traversePatternEdge(OMatchStatement.MatchContext matchContext,
OIdentifiable startingPoint,
OCommandContext iCommandContext) |
Constructor and Description |
---|
WhileStep(OBooleanExpression condition,
List<OStatement> statements,
OCommandContext ctx,
boolean enableProfiling) |
Modifier and Type | Field and Description |
---|---|
protected OCommandContext |
OETLAbstractComponent.context |
protected OCommandContext |
OETLPipeline.context |
protected OCommandContext |
OETLProcessor.context |
Modifier and Type | Method and Description |
---|---|
protected OCommandContext |
OETLProcessorConfigurator.createDefaultContext() |
OCommandContext |
OETLPipeline.getContext() |
OCommandContext |
OETLProcessor.getContext() |
Modifier and Type | Method and Description |
---|---|
protected void |
OETLProcessor.configRunBehaviour(OCommandContext context) |
void |
OETLAbstractComponent.configure(ODocument iConfiguration,
OCommandContext iContext) |
void |
OETLComponent.configure(ODocument configuration,
OCommandContext context)
Called by the @OETLProcessor
|
protected void |
OETLProcessorConfigurator.configureComponent(OETLComponent iComponent,
ODocument iCfg,
OCommandContext iContext) |
OETLProcessor |
OETLProcessorConfigurator.parse(ODocument cfg,
OCommandContext context) |
void |
OETLAbstractPipelineComponent.setContext(OCommandContext context) |
void |
OETLPipelineComponent.setContext(OCommandContext context) |
Constructor and Description |
---|
OETLProcessor(List<OETLBlock> iBeginBlocks,
OETLSource iSource,
OETLExtractor iExtractor,
List<OETLTransformer> iTransformers,
OETLLoader iLoader,
List<OETLBlock> iEndBlocks,
OCommandContext iContext)
Creates an ETL processor by setting all the components on construction.
|
Modifier and Type | Method and Description |
---|---|
void |
OETLCodeBlock.configure(ODocument iConfiguration,
OCommandContext iContext) |
void |
OETLLetBlock.configure(ODocument iConfiguration,
OCommandContext iContext) |
void |
OETLConsoleBlock.configure(ODocument iConfiguration,
OCommandContext iContext) |
void |
OETLAbstractBlock.setContext(OCommandContext iContext) |
void |
OETLBlock.setContext(OCommandContext context) |
Modifier and Type | Class and Description |
---|---|
class |
OETLContext
OETLContext extends OBasicCommandContext, in order to handle the following additional elements: -
message handler for application messages
|
Modifier and Type | Method and Description |
---|---|
OCommandContext |
OETLContextWrapper.getContext() |
Modifier and Type | Method and Description |
---|---|
void |
OETLContextWrapper.setContext(OCommandContext context) |
Modifier and Type | Method and Description |
---|---|
void |
OETLRowExtractor.configure(ODocument iConfiguration,
OCommandContext iContext) |
void |
OETLCSVExtractor.configure(ODocument iConfiguration,
OCommandContext iContext) |
void |
OETLXmlExtractor.configure(ODocument iConfiguration,
OCommandContext iContext) |
void |
OETLJDBCExtractor.configure(ODocument iConfiguration,
OCommandContext iContext) |
Modifier and Type | Method and Description |
---|---|
void |
OETLDefaultImporterListener.onAfterFile(ODatabaseDocument db,
OCommandContext iContext) |
void |
OETLScriptImporterListener.onAfterFile(ODatabaseDocument db,
OCommandContext iContext) |
void |
OETLImporterListener.onAfterFile(ODatabaseDocument db,
OCommandContext iContext) |
void |
OETLDefaultImporterListener.onAfterLine(ODatabaseDocument db,
OCommandContext iContext) |
void |
OETLScriptImporterListener.onAfterLine(ODatabaseDocument db,
OCommandContext iContext) |
void |
OETLImporterListener.onAfterLine(ODatabaseDocument db,
OCommandContext iContext) |
void |
OETLDefaultImporterListener.onBeforeFile(ODatabaseDocument db,
OCommandContext iContext) |
void |
OETLScriptImporterListener.onBeforeFile(ODatabaseDocument db,
OCommandContext iContext) |
void |
OETLImporterListener.onBeforeFile(ODatabaseDocument db,
OCommandContext iContext) |
boolean |
OETLDefaultImporterListener.onBeforeLine(ODatabaseDocument db,
OCommandContext iContext) |
boolean |
OETLScriptImporterListener.onBeforeLine(ODatabaseDocument db,
OCommandContext iContext) |
boolean |
OETLImporterListener.onBeforeLine(ODatabaseDocument db,
OCommandContext iContext) |
void |
OETLDefaultImporterListener.onDump(ODatabaseDocument db,
OCommandContext iContext) |
void |
OETLScriptImporterListener.onDump(ODatabaseDocument db,
OCommandContext iContext) |
void |
OETLImporterListener.onDump(ODatabaseDocument db,
OCommandContext iContext) |
void |
OETLDefaultImporterListener.onJoinNotFound(ODatabaseDocument db,
OCommandContext iContext,
OIndex iIndex,
Object iKey) |
void |
OETLScriptImporterListener.onJoinNotFound(ODatabaseDocument db,
OCommandContext iContext,
OIndex iIndex,
Object iKey) |
void |
OETLImporterListener.onJoinNotFound(ODatabaseDocument db,
OCommandContext iContext,
OIndex iIndex,
Object iKey) |
void |
OETLDefaultImporterListener.validate(ODatabaseDocument db,
OCommandContext iContext,
ODocument iRecord) |
void |
OETLScriptImporterListener.validate(ODatabaseDocument db,
OCommandContext iContext,
ODocument iRecord) |
void |
OETLImporterListener.validate(ODatabaseDocument db,
OCommandContext iContext,
ODocument iRecord) |
Modifier and Type | Method and Description |
---|---|
void |
OETLOrientDBLoader.configure(ODocument conf,
OCommandContext iContext) |
void |
OETLOutputLoader.load(ODatabaseDocument db,
Object input,
OCommandContext context) |
void |
OETLOrientDBLoader.load(ODatabaseDocument db,
Object input,
OCommandContext context) |
void |
OETLLoader.load(ODatabaseDocument db,
Object input,
OCommandContext context) |
Modifier and Type | Method and Description |
---|---|
void |
OETLHttpSource.configure(ODocument iConfiguration,
OCommandContext iContext) |
void |
OETLContentSource.configure(ODocument iConfiguration,
OCommandContext iContext) |
void |
OETLFileSource.configure(ODocument iConfiguration,
OCommandContext iContext) |
Modifier and Type | Method and Description |
---|---|
void |
OETLEdgeTransformer.configure(ODocument iConfiguration,
OCommandContext iContext) |
void |
OETLCodeTransformer.configure(ODocument iConfiguration,
OCommandContext iContext) |
void |
OETLFlowTransformer.configure(ODocument iConfiguration,
OCommandContext iContext) |
void |
OETLLogTransformer.configure(ODocument iConfiguration,
OCommandContext iContext) |
void |
OETLAbstractLookupTransformer.configure(ODocument iConfiguration,
OCommandContext iContext) |
void |
OETLVertexTransformer.configure(ODocument iConfiguration,
OCommandContext iContext) |
void |
OETLBlockTransformer.configure(ODocument iConfiguration,
OCommandContext iContext) |
void |
OETLLinkTransformer.configure(ODocument iConfiguration,
OCommandContext iContext) |
void |
OETLFieldTransformer.configure(ODocument iConfiguration,
OCommandContext iContext) |
void |
OETLCommandTransformer.configure(ODocument conf,
OCommandContext ctx) |
void |
OETLBlockTransformer.setContext(OCommandContext context) |
Modifier and Type | Field and Description |
---|---|
protected OCommandContext |
OSQLFunctionHeuristicPathFinderAbstract.context |
protected OCommandContext |
OSQLFunctionPathFinder.context |
Modifier and Type | Method and Description |
---|---|
Object |
OSQLFunctionGremlin.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
LinkedList<OrientVertex> |
OSQLFunctionAstar.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext)
Deprecated.
|
Object |
OSQLFunctionLabel.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParameters,
OCommandContext iContext) |
List<ORID> |
OSQLFunctionShortestPath.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext)
Deprecated.
|
LinkedList<OrientVertex> |
OSQLFunctionDijkstra.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext)
Deprecated.
|
protected LinkedList<OrientVertex> |
OSQLFunctionPathFinder.execute(OCommandContext iContext) |
Modifier and Type | Method and Description |
---|---|
OCommandContext |
OCommandSQLPojoWrapper.getContext() |
Modifier and Type | Method and Description |
---|---|
OCommandRequest |
OCommandSQLPojoWrapper.setContext(OCommandContext iContext) |
Modifier and Type | Method and Description |
---|---|
boolean |
OSpatialFunctionAbstractIndexable.allowsIndexedExecution(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
boolean |
OSpatialFunctionAbstractIndexable.canExecuteInline(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
long |
OSpatialFunctionAbstractIndexable.estimate(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
long |
OSTDistanceSphereFunction.estimate(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
Object |
OSTContainsFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSTAsGeoJSONFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSTWithinFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSTAsTextFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSTDisjointFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSTDistanceFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSTBufferFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSTGeomFromGeoJSONFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSTIntersectsFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSTDWithinFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSTGeomFromTextFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSTAsBinaryFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSTEqualsFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSTEnvelopFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSTDistanceSphereFunction.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
Object |
OSTSrid.execute(Object iThis,
OIdentifiable iCurrentRecord,
Object iCurrentResult,
Object[] iParams,
OCommandContext iContext) |
protected void |
OSTDWithinFunction.onAfterParsing(Map<String,Object> params,
OExpression[] args,
OCommandContext ctx,
Object rightValue) |
protected void |
OSpatialFunctionAbstractIndexable.onAfterParsing(Map<String,Object> params,
OExpression[] args,
OCommandContext ctx,
Object rightValue) |
protected void |
OSTDistanceSphereFunction.onAfterParsing(Map<String,Object> params,
OExpression[] args,
OCommandContext ctx,
Object rightValue) |
protected Iterable<OIdentifiable> |
OSpatialFunctionAbstractIndexable.results(OFromClause target,
OExpression[] args,
OCommandContext ctx,
Object rightValue) |
Iterable<OIdentifiable> |
OSTContainsFunction.searchFromTarget(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
Iterable<OIdentifiable> |
OSTWithinFunction.searchFromTarget(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
Iterable<OIdentifiable> |
OSTIntersectsFunction.searchFromTarget(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
Iterable<OIdentifiable> |
OSTDWithinFunction.searchFromTarget(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
Iterable<OIdentifiable> |
OSTDistanceSphereFunction.searchFromTarget(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
boolean |
OSpatialFunctionAbstractIndexable.shouldExecuteAfterSearch(OFromClause target,
OBinaryCompareOperator operator,
Object rightValue,
OCommandContext ctx,
OExpression... args) |
Modifier and Type | Method and Description |
---|---|
Object |
OLuceneWithinOperator.evaluateRecord(OIdentifiable iRecord,
ODocument iCurrentResult,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext,
ODocumentSerializer serializer) |
Object |
OLuceneNearOperator.evaluateRecord(OIdentifiable iRecord,
ODocument iCurrentResult,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext,
ODocumentSerializer serializer) |
Object |
OLuceneOverlapOperator.evaluateRecord(OIdentifiable iRecord,
ODocument iCurrentResult,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext,
ODocumentSerializer serializer) |
Object |
OLuceneSpatialOperator.evaluateRecord(OIdentifiable iRecord,
ODocument iCurrentResult,
OSQLFilterCondition iCondition,
Object iLeft,
Object iRight,
OCommandContext iContext,
ODocumentSerializer serializer) |
Stream<ORawPair<Object,ORID>> |
OLuceneWithinOperator.executeIndexQuery(OCommandContext iContext,
OIndex index,
List<Object> keyParams,
boolean ascSortOrder) |
Stream<ORawPair<Object,ORID>> |
OLuceneNearOperator.executeIndexQuery(OCommandContext iContext,
OIndex index,
List<Object> keyParams,
boolean ascSortOrder) |
Stream<ORawPair<Object,ORID>> |
OLuceneOverlapOperator.executeIndexQuery(OCommandContext iContext,
OIndex index,
List<Object> keyParams,
boolean ascSortOrder) |
OIndexSearchResult |
OLuceneWithinOperator.getOIndexSearchResult(OClass iSchemaClass,
OSQLFilterCondition iCondition,
List<OIndexSearchResult> iIndexSearchResults,
OCommandContext context) |
OIndexSearchResult |
OLuceneNearOperator.getOIndexSearchResult(OClass iSchemaClass,
OSQLFilterCondition iCondition,
List<OIndexSearchResult> iIndexSearchResults,
OCommandContext context) |
OIndexSearchResult |
OLuceneSpatialOperator.getOIndexSearchResult(OClass iSchemaClass,
OSQLFilterCondition iCondition,
List<OIndexSearchResult> iIndexSearchResults,
OCommandContext context) |
Constructor and Description |
---|
OSpatialQueryContext(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) |
Modifier and Type | Method and Description |
---|---|
OCommandContext |
OrientGraphCommand.getContext() |
Modifier and Type | Method and Description |
---|---|
OCommandRequest |
OrientGraphCommand.setContext(OCommandContext iContext) |
Copyright © 2009–2020 OrientDB. All rights reserved.