Modifier and Type | Method and Description |
---|---|
List<Pair<StringPatternSet,Boolean>> |
ConfigurationRuntimeMetricsReporting.StmtGroupMetrics.getPatterns()
Returns a list of patterns that indicate whether a statement, by the statement name matching or
not matching each pattern, falls within the statement group.
|
Modifier and Type | Method and Description |
---|---|
static <K,V> Pair<K,V> |
Pair.createPair(K key,
V value) |
Pair<E,String> |
PathRegistry.getAnyModuleExpectSingle(K entityKey,
Set<String> moduleUses) |
Pair<E,String> |
PathModuleEntry.getAnyModuleExpectSingle(String entityName,
PathRegistryObjectType objectType,
Set<String> moduleNames) |
Modifier and Type | Method and Description |
---|---|
Pair<Class,PluggableObjectEntry> |
PluggableObjectRegistryImpl.lookup(String nameSpace,
String name) |
Pair<Class,PluggableObjectEntry> |
PluggableObjectRegistry.lookup(String nameSpace,
String name) |
Modifier and Type | Method and Description |
---|---|
LinkedHashMap<String,Pair<EventType,String>> |
PatternStreamSpecCompiled.getArrayEventTypes()
Returns event types tagged in the pattern expression under a repeat-operator.
|
LinkedHashMap<String,Pair<EventType,String>> |
MatchEventSpec.getArrayEventTypes() |
List<Pair<String,Object>> |
AnnotationDesc.getAttributes()
Returns annotation attributes.
|
Map<String,Map<String,Pair<Class,PluggableObjectEntry>>> |
PluggableObjectCollection.getPluggables()
Returns the underlying nested map of namespace keys and name-to-object maps.
|
LinkedHashMap<String,Pair<EventType,String>> |
PatternStreamSpecCompiled.getTaggedEventTypes()
Returns event types tagged in the pattern expression.
|
LinkedHashMap<String,Pair<EventType,String>> |
MatchEventSpec.getTaggedEventTypes() |
Constructor and Description |
---|
CreateExpressionDesc(Pair<ExpressionDeclItem,ExpressionScriptProvided> pair) |
Modifier and Type | Field and Description |
---|---|
LinkedHashMap<String,Pair<EventType,String>> |
FilterSpecCompilerArgs.arrayEventTypes |
LinkedHashMap<String,Pair<EventType,String>> |
FilterSpecCompilerArgs.taggedEventTypes |
Modifier and Type | Method and Description |
---|---|
static FilterSpecCompiled |
FilterSpecCompiler.build(List<ExprNode> validatedNodes,
EventType eventType,
String eventTypeName,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
String optionalStreamName,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices compileTimeServices) |
static FilterSpecCompiled |
FilterSpecCompiler.build(List<ExprNode> validatedNodes,
EventType eventType,
String eventTypeName,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
String optionalStreamName,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices compileTimeServices) |
static FilterSpecCompiled |
FilterSpecCompiler.buildNoStmtCtx(List<ExprNode> validatedNodes,
EventType eventType,
String eventTypeName,
String optionalStreamName,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices compileTimeServices) |
static FilterSpecCompiled |
FilterSpecCompiler.buildNoStmtCtx(List<ExprNode> validatedNodes,
EventType eventType,
String eventTypeName,
String optionalStreamName,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices compileTimeServices) |
protected static FilterSpecParamForge |
FilterSpecCompilerMakeParamUtil.makeFilterParam(ExprNode constituent,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
String statementName)
For a given expression determine if this is optimizable and create the filter parameter
representing the expression, or null if not optimizable.
|
static FilterSpecCompiled |
FilterSpecCompiler.makeFilterSpec(EventType eventType,
String eventTypeName,
List<ExprNode> filterExpessions,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
String optionalStreamName,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices services) |
static FilterSpecCompiled |
FilterSpecCompiler.makeFilterSpec(EventType eventType,
String eventTypeName,
List<ExprNode> filterExpessions,
PropertyEvalSpec optionalPropertyEvalSpec,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
String optionalStreamName,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices services) |
static List<ExprNode> |
FilterSpecCompiler.validateAllowSubquery(ExprNodeOrigin exprNodeOrigin,
List<ExprNode> exprNodes,
StreamTypeService streamTypeService,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices services) |
static List<ExprNode> |
FilterSpecCompiler.validateAllowSubquery(ExprNodeOrigin exprNodeOrigin,
List<ExprNode> exprNodes,
StreamTypeService streamTypeService,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices services) |
Constructor and Description |
---|
FilterSpecCompilerArgs(LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
ContextCompileTimeDescriptor contextDescriptor,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices compileTimeServices) |
FilterSpecCompilerArgs(LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
ContextCompileTimeDescriptor contextDescriptor,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices compileTimeServices) |
Modifier and Type | Method and Description |
---|---|
static Pair<ResultSetProcessor,AggregationService> |
StatementAgentInstanceFactoryUtil.startResultSetAndAggregation(ResultSetProcessorFactoryProvider resultSetProcessorPrototype,
AgentInstanceContext agentInstanceContext,
boolean isSubquery,
Integer subqueryNumber) |
Constructor and Description |
---|
ContextControllerHashedGetterSingleRowForge(Pair<Class,ClasspathImportSingleRowDesc> func,
List<ExprNode> parameters,
int granularity,
EventType eventType,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices services) |
Modifier and Type | Method and Description |
---|---|
List<Pair<ExprNode,int[]>> |
FilterExprAnalyzerDTIntervalAffector.getKeyExpressions() |
List<Pair<ExprNode,int[]>> |
FilterExprAnalyzerDTBetweenAffector.getKeyExpressions() |
Modifier and Type | Method and Description |
---|---|
static Pair<String,ExprNode> |
ExprNodeUtilityValidate.checkGetAssignmentToProp(ExprNode node) |
static Pair<String,ExprNode> |
ExprNodeUtilityValidate.checkGetAssignmentToVariableOrProp(ExprNode node) |
static Pair<PropertyResolutionDescriptor,String> |
ExprIdentNodeUtil.getTypeFromStream(StreamTypeService streamTypeService,
String propertyNameNestable,
boolean explicitPropertiesOnly,
boolean obtainFragment,
TableCompileTimeResolver tableCompileTimeResolver) |
protected static Pair<PropertyResolutionDescriptor,String> |
ExprIdentNodeUtil.getTypeFromStream(StreamTypeService streamTypeService,
String unresolvedPropertyName,
String streamOrPropertyNameMayEscaped,
boolean obtainFragment,
TableCompileTimeResolver tableCompileTimeResolver) |
protected static Pair<PropertyResolutionDescriptor,String> |
ExprIdentNodeUtil.getTypeFromStreamExplicitProperties(StreamTypeService streamTypeService,
String unresolvedPropertyName,
String streamOrPropertyName,
boolean obtainFragment) |
Modifier and Type | Method and Description |
---|---|
static List<Pair<ExprNode,ExprNode>> |
ExprNodeUtilityQuery.findExpression(ExprNode selectExpression,
ExprNode searchExpression) |
static List<Pair<Integer,String>> |
ExprNodeUtilityQuery.getExpressionProperties(ExprNode exprNode,
boolean visitAggregateNodes) |
Modifier and Type | Method and Description |
---|---|
static Pair<ExprDeclaredNodeImpl,StatementSpecMapContext> |
ExprDeclaredHelper.getExistsDeclaredExpr(String name,
List<ExprNode> parameters,
Collection<ExpressionDeclItem> stmtLocalExpressions,
ContextCompileTimeDescriptor contextCompileTimeDescriptor,
StatementSpecMapEnv mapEnv) |
Modifier and Type | Method and Description |
---|---|
static Boolean |
ExprInstanceofNodeForgeEval.instanceofCacheCheckOrAdd(Class[] classes,
CopyOnWriteArrayList<Pair<Class,Boolean>> resultCache,
Object result)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
Modifier and Type | Method and Description |
---|---|
List<Pair<Integer,String>> |
ExprNodeIdentifierVisitor.getExprProperties()
Returns list of event property stream numbers and names that uniquely identify which
property is from whcih stream, and the name of each.
|
List<Pair<ExprNode,ExprIdentNode>> |
ExprNodeIdentifierCollectVisitorWContainer.getExprProperties()
Returns list of event property stream numbers and names that uniquely identify which
property is from whcih stream, and the name of each.
|
List<Pair<ExprNode,ExprGroupingIdNode>> |
ExprNodeGroupingVisitorWParent.getGroupingIdNodes() |
List<Pair<ExprNode,ExprGroupingNode>> |
ExprNodeGroupingVisitorWParent.getGroupingNodes() |
List<Pair<ExprNode,ExprIdentNode>> |
ExprNodeIdentVisitorWParent.getIdentNodes() |
List<Pair<ExprNode,ExprPreviousNode>> |
ExprNodePreviousVisitorWParent.getPrevious()
Returns the pair of previous nodes and their parent expression.
|
Modifier and Type | Method and Description |
---|---|
Pair<HistoricalIndexLookupStrategyForge,PollResultIndexingStrategyForge> |
HistoricalStreamIndexListForge.getStrategy(int streamViewStreamNum)
Get the strategies to use for polling from a given stream.
|
Modifier and Type | Method and Description |
---|---|
Pair<Connection,PreparedStatement> |
ConnectionCacheNoCacheImpl.getConnection() |
Pair<Connection,PreparedStatement> |
ConnectionCacheImpl.getConnection() |
abstract Pair<Connection,PreparedStatement> |
ConnectionCache.getConnection()
Returns a cached or new connection and statement pair.
|
protected Pair<Connection,PreparedStatement> |
ConnectionCache.makeNew()
Make a new pair of resources.
|
Modifier and Type | Method and Description |
---|---|
protected static void |
ConnectionCache.close(Pair<Connection,PreparedStatement> pair)
Close resources.
|
void |
ConnectionCacheNoCacheImpl.doneWith(Pair<Connection,PreparedStatement> pair) |
void |
ConnectionCacheImpl.doneWith(Pair<Connection,PreparedStatement> pair) |
abstract void |
ConnectionCache.doneWith(Pair<Connection,PreparedStatement> pair)
Indicate to return the connection and statement pair after use.
|
Modifier and Type | Method and Description |
---|---|
static Pair<MethodTargetStrategyForge,MethodConversionStrategyForge> |
PollExecStrategyPlanner.plan(MethodPollingViewableMeta metadata,
Method targetMethod,
EventType eventType) |
Constructor and Description |
---|
FilterExprAnalyzerAffectorIndexProvision(String operationName,
ExprNode[] indexExpressions,
List<Pair<ExprNode,int[]>> keyExpressions,
int streamNumIndex) |
Modifier and Type | Method and Description |
---|---|
static Pair<HistoricalIndexLookupStrategyForge,PollResultIndexingStrategyForge> |
JoinSetComposerPrototypeForgeFactory.determineIndexing(QueryGraphForge queryGraph,
EventType polledViewType,
EventType streamViewType,
int polledViewStreamNum,
int streamViewStreamNum)
Constructs indexing and lookup strategy for a given relationship that a historical stream may have with another
stream (historical or not) that looks up into results of a poll of a historical stream.
|
Modifier and Type | Method and Description |
---|---|
void |
QueryGraphForge.addCustomIndex(String operationName,
ExprNode[] indexExpressions,
List<Pair<ExprNode,int[]>> streamKeys,
int streamValue) |
Modifier and Type | Method and Description |
---|---|
Pair<TableLookupIndexReqKey,int[]> |
QueryPlanIndexForge.getIndexNum(String[] indexProps,
String[] rangeProps)
Find a matching index for the property names supplied.
|
Modifier and Type | Method and Description |
---|---|
Pair<IndexMultiKey,EventTableAndNamePair> |
EventTableIndexRepository.addExplicitIndexOrReuse(QueryPlanIndexItem desc,
Iterable<EventBean> prefilledEvents,
EventType indexedType,
String indexName,
String indexModuleName,
AgentInstanceContext agentInstanceContext,
Object optionalSerde) |
static Pair<IndexMultiKey,EventTableIndexEntryBase> |
EventTableIndexUtil.findIndexBestAvailable(Map<IndexMultiKey,? extends EventTableIndexEntryBase> tablesAvailable,
Set<String> keyPropertyNames,
Set<String> rangePropertyNames,
List<IndexHintInstruction> optionalIndexHintInstructions) |
Pair<IndexMultiKey,EventTableAndNamePair> |
EventTableIndexRepository.findTable(Set<String> keyPropertyNames,
Set<String> rangePropertyNames,
List<IndexHintInstruction> optionalIndexHintInstructions) |
Constructor and Description |
---|
MatchedEventConvertorForge(LinkedHashMap<String,Pair<EventType,String>> filterTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
LinkedHashSet<String> allTags) |
MatchedEventConvertorForge(LinkedHashMap<String,Pair<EventType,String>> filterTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
LinkedHashSet<String> allTags) |
Modifier and Type | Method and Description |
---|---|
List<Pair<Integer,int[]>> |
RowRecogDesc.getNextStatesPerState() |
LinkedHashMap<String,Pair<Integer,Boolean>> |
RowRecogDesc.getVariableStreams() |
Modifier and Type | Method and Description |
---|---|
protected static RowRecogNFAStrandResult |
RowRecogHelper.buildStartStates(RowRecogExprNode parent,
Map<String,ExprNode> variableDefinitions,
Map<String,Pair<Integer,Boolean>> variableStreams,
boolean[] exprRequiresMultimatchState)
Build a list of start states from the parent node.
|
protected static String |
RowRecogNFAViewUtil.printStates(List<RowRecogNFAStateEntry> states,
Map<Integer,String> streamsVariables,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
void |
RowRecogDesc.setNextStatesPerState(List<Pair<Integer,int[]>> nextStatesPerState) |
void |
RowRecogDesc.setVariableStreams(LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams) |
Constructor and Description |
---|
RowRecogDescForge(EventType parentEventType,
EventType rowEventType,
EventType compositeEventType,
EventType multimatchEventType,
int[] multimatchStreamNumToVariable,
int[] multimatchVariableToStreamNum,
ExprNode[] partitionBy,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
boolean hasInterval,
boolean iterateOnly,
boolean unbound,
boolean orTerminated,
boolean collectMultimatches,
boolean defineAsksMultimatches,
int numEventsEventsPerStreamDefine,
String[] multimatchVariablesArray,
RowRecogNFAStateForge[] startStates,
RowRecogNFAStateForge[] allStates,
boolean allMatches,
MatchRecognizeSkipEnum skip,
ExprNode[] columnEvaluators,
String[] columnNames,
TimePeriodComputeForge intervalCompute,
int[] previousRandomAccessIndexes,
AggregationServiceForgeDesc[] aggregationServices) |
RowRecogPartitionTerminationStateComparator(int[] multimatchStreamNumToVariable,
Map<String,Pair<Integer,Boolean>> variableStreams) |
Modifier and Type | Method and Description |
---|---|
List<Pair<RowRecogExprNodeAtom,RowRecogExprNode>> |
RowRecogExprNodeVisitorRepeat.getAtoms() |
Modifier and Type | Method and Description |
---|---|
protected static Pair<Integer,String> |
StreamTypeServiceUtil.findLevMatch(EventType[] eventTypes,
String propertyName) |
protected static Pair<Integer,String> |
StreamTypeServiceUtil.findLevMatch(String propertyName,
EventType eventType) |
Pair<Integer,String> |
StreamTypesException.getOptionalSuggestion()
Returns the optional suggestion for a matching name.
|
Pair<Integer,String> |
StreamTypesExceptionSuggestionGen.getSuggestion() |
Constructor and Description |
---|
StreamTypeServiceImpl(LinkedHashMap<String,Pair<EventType,String>> namesAndTypes,
boolean isStreamZeroUnambigous,
boolean requireStreamNames)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
static void |
SubSelectHelperFilters.handleSubselectSelectClauses(ExprSubselectNode subselect,
EventType outerEventType,
String outerEventTypeName,
String outerStreamName,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices services) |
static void |
SubSelectHelperFilters.handleSubselectSelectClauses(ExprSubselectNode subselect,
EventType outerEventType,
String outerEventTypeName,
String outerStreamName,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StatementRawInfo statementRawInfo,
StatementCompileTimeServices services) |
Constructor and Description |
---|
SubSelectStrategyFactoryLocalViewPreloadedForge(List<ViewFactoryForge> viewForges,
ViewResourceDelegateDesc viewResourceDelegateDesc,
Pair<EventTableFactoryFactoryForge,SubordTableLookupStrategyFactoryForge> lookupStrategy,
ExprNode filterExprNode,
boolean correlatedSubquery,
AggregationServiceForgeDesc aggregationServiceForgeDesc,
int subqueryNumber,
ExprNode[] groupKeys,
NamedWindowMetaData namedWindow,
ExprNode namedWindowFilterExpr,
QueryGraphForge namedWindowFilterQueryGraph) |
Modifier and Type | Method and Description |
---|---|
Map<Integer,Pair<Integer,Object>> |
VariableVersionThreadEntry.getUncommitted()
Returns a map of variable number and uncommitted value, or empty map or null if none exist
|
Modifier and Type | Method and Description |
---|---|
void |
VariableVersionThreadEntry.setUncommitted(Map<Integer,Pair<Integer,Object>> uncommitted)
Sets a map of variable number and uncommitted value, or empty map or null if none exist
|
Constructor and Description |
---|
VariableVersionThreadEntry(int version,
Map<Integer,Pair<Integer,Object>> uncommitted)
Ctor.
|
Modifier and Type | Method and Description |
---|---|
static Pair<IndexMultiKey,EventTable> |
VirtualDWQueryPlanUtil.getFireAndForgetDesc(EventType eventType,
Set<String> keysAvailable,
Set<String> rangesAvailable) |
static Pair<IndexMultiKey,VirtualDWEventTable> |
VirtualDWQueryPlanUtil.getSubordinateQueryDesc(boolean unique,
IndexedPropDesc[] hashedProps,
IndexedPropDesc[] btreeProps) |
Modifier and Type | Field and Description |
---|---|
protected Map<String,Pair<EventPropertyDescriptor,ObjectArrayEventBeanPropertyWriter>> |
ObjectArrayEventType.propertyWriters |
Modifier and Type | Method and Description |
---|---|
static Pair<Constructor,ExprForge[]> |
InstanceManufacturerUtil.getManufacturer(Class targetClass,
ClasspathImportServiceCompileTime classpathImportService,
ExprForge[] exprForges,
Object[] expressionReturnTypes) |
Modifier and Type | Method and Description |
---|---|
static Pair<EventType[],Set<EventType>> |
EventTypeUtility.getSuperTypesDepthFirst(Set<String> superTypesSet,
EventUnderlyingType representation,
EventTypeNameResolver eventTypeNameResolver) |
static Pair<EventType[],Set<EventType>> |
EventTypeUtility.getSuperTypesDepthFirst(String[] superTypesSet,
EventUnderlyingType representation,
EventTypeNameResolver eventTypeNameResolver) |
Modifier and Type | Method and Description |
---|---|
Map<String,Pair<EventType,String>> |
TaggedCompositeEventType.getTaggedEventTypes()
Returns the event types for each composing event.
|
Modifier and Type | Field and Description |
---|---|
protected Map<String,Pair<EventPropertyDescriptor,MapEventBeanPropertyWriter>> |
MapEventType.propertyWriters |
Modifier and Type | Method and Description |
---|---|
LinkedHashMap<String,Pair<EventType,String>> |
FilterSpecParamExprNodeForge.getTaggedEventTypes()
Returns the map of tag/stream names to event types that the filter expressions map use (for patterns)
|
Constructor and Description |
---|
FilterSpecParamExprNodeForge(ExprFilterSpecLookupableForge lookupable,
FilterOperator filterOperator,
ExprNode exprNode,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
boolean hasSubquery,
boolean hasTableAccess,
boolean hasVariable,
StatementCompileTimeServices compileTimeServices) |
FilterSpecParamExprNodeForge(ExprFilterSpecLookupableForge lookupable,
FilterOperator filterOperator,
ExprNode exprNode,
LinkedHashMap<String,Pair<EventType,String>> taggedEventTypes,
LinkedHashMap<String,Pair<EventType,String>> arrayEventTypes,
StreamTypeService streamTypeService,
boolean hasSubquery,
boolean hasTableAccess,
boolean hasVariable,
StatementCompileTimeServices compileTimeServices) |
Modifier and Type | Method and Description |
---|---|
void |
InstrumentationCommonDefault.aRegExState(List<RowRecogNFAStateEntry> next,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
void |
InstrumentationCommon.aRegExState(List<RowRecogNFAStateEntry> next,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
void |
InstrumentationCommonDefault.aRegExStateStart(List<RowRecogNFAStateEntry> nextStates,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
void |
InstrumentationCommon.aRegExStateStart(List<RowRecogNFAStateEntry> nextStates,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
void |
InstrumentationCommonDefault.qRegExState(RowRecogNFAStateEntry currentState,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
void |
InstrumentationCommon.qRegExState(RowRecogNFAStateEntry currentState,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
void |
InstrumentationCommonDefault.qRegExStateStart(RowRecogNFAState startState,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
void |
InstrumentationCommon.qRegExStateStart(RowRecogNFAState startState,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
void |
InstrumentationCommonDefault.qRegIntervalState(RowRecogNFAStateEntry endState,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable,
long runtimeTime) |
void |
InstrumentationCommon.qRegIntervalState(RowRecogNFAStateEntry endState,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable,
long runtimeTime) |
void |
InstrumentationCommonDefault.qRegMeasure(RowRecogNFAStateEntry endState,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
void |
InstrumentationCommon.qRegMeasure(RowRecogNFAStateEntry endState,
LinkedHashMap<String,Pair<Integer,Boolean>> variableStreams,
int[] multimatchStreamNumToVariable) |
Modifier and Type | Method and Description |
---|---|
Pair<Class,ClasspathImportSingleRowDesc> |
ClasspathImportServiceCompileTime.resolveSingleRow(String name) |
Modifier and Type | Method and Description |
---|---|
static Boolean |
StringPatternSetUtil.evaluate(boolean defaultValue,
List<Pair<StringPatternSet,Boolean>> patterns,
String literal)
Executes a seriers of include/exclude patterns against a match string,
returning the last pattern match result as boolean in/out.
|
Modifier and Type | Method and Description |
---|---|
static Object |
SimpleTypeCasterAnyType.simpleTypeCasterCast(Object object,
Class typeToCastTo,
CopyOnWriteArraySet<Pair<Class,Boolean>> pairs)
NOTE: Code-generation-invoked method, method name and parameter order matters
|
Copyright © 2005–2018. All rights reserved.