arrIndexLabeler | |
AST_FileIO | This Namespace supports the file I/O for the AST |
AstDOTGenerationExtended_Defaults | |
NamedExtraNodeInfo | |
AddressExtraNodeInfo | |
ContainerSizeExtraNodeInfo | |
LValueExtraNodeInfo | |
TypeExtraNodeInfo | |
DefaultExtraNodeInfo | |
DefaultExtraNodeOptions | |
DefaultExtraEdgeInfo | |
DefaultExtraEdgeOptions | |
AstFromString | Liao 4/13/2011 |
Backstroke | |
CFG | A class holding a Control Flow Graph |
EdgeCopier | This class is used to copy edges when calling copy_graph() |
VertexCopier | This class is used to copy vertices when calling copy_graph() |
FullCFGNodeFilter | |
InterestingCFGNodeFilter | |
BaseCFG | |
iterator | |
checkpoint | |
back_iterator | |
dataflow | |
back_dataflow | |
boost | |
ByteOrder | |
CallTargetSet | |
cfgUtils | |
Combinatorics | |
DL_Stack | |
CommandlineProcessing | |
Dbg | |
dbgBuf | |
dbgStream | |
DominatorTreesAndDominanceFrontiers | |
ControlFlowGraph | |
ControlNode | |
DominanceFrontier | |
DominatorTree | |
TemplatedDominanceFrontier | |
DominatorForwardBackwardWrapperClass | This class provides a uniform view of the CFG dissregarding the direction of the CFG-traversal (forward/backward) |
TemplatedDominatorTree | TemplatedDominatorTree constructs a dominator/postdominator tree for a cfg. For the template parameter any cfg following Jeremias interface may be used |
DefaultBasicDominatorTreeIsStatementFilter | |
DUVariableAnalysisExt | |
IntegerOps | Bit-wise operations on integers |
SHL1 | Bitmask constant with bit n set |
GenMask | Bit mask constant with bits 0 through n-1 set |
IntegerOpsPrivate | |
NumBits | |
SHL1Helper | |
SHL1Helper< T, Count, true > | |
SHL1Helper< T, Count, false > | |
OmpSupport | |
SgVarRefExpVisitor | |
OmpAttributeList | |
OmpAttribute | |
translationDriver | A driver to traverse AST trees and invoke individual translators for OpenMP constructs, (not in use) Postorder is preferred |
ProcessExpression | |
rose | |
ROSE | |
Rose | |
Frontend | |
Java | |
ROSE_Callbacks | User callbacks |
List | List of callback functors |
rose_hash | |
eqstr_string | |
hash_integer | Hash name support for symbol tables within ROSE |
hash_integer_pair | |
eqstr_integer_pair | |
eqstr_graph_node | |
eqstr_graph_edge | |
hash_graph_node | |
ROSE_token_ids | |
rwAccessLabeler | |
SageBuilder | |
SageBuilderAsm | |
SageInterface | |
DeclarationSets | |
UniqueNameAttribute | A persistent attribute to represent a unique name for an expression |
hash_nodeptr | |
OutputLocalSymbolTables | |
StatementGenerator | Interface for creating a statement whose computation writes its answer into a given variable |
SDG | |
CDGEdge | |
ControlDependenceGraph | |
ControlDependence | |
DDGEdge | Define the edge type of DDG |
DataDependenceGraph | |
PDGNode | |
PDGEdge | Define the edge type of PDG |
ProgramDependenceGraph | |
SDGNode | |
SDGEdge | |
SystemDependenceGraph | |
CallSiteInfo | |
sg | |
ScopeSetter | Functor setting the scope of a sage node to a specified (at Functor construction time) scope |
VarRefBuilder | Functor building a variable reference from an initialized name |
InitNameCloner | Functor copying an initialized name into a different scope |
SageInserter | Generic inserter for sage containers |
ConstLike | Projects the constness of T1 on T2 |
ConstLike< const T1, T2 > | |
DispatchHandler | |
VisitDispatcher | Implementation for dispatcher objects ( invokes roseVisitor.handle(sgnode) ) |
VisitDispatcher< T * > | Implementation for dispatcher pointers ( invokes roseVisitor->handle(sgnode) ) |
DefaultHandler | |
AncestorTypeFinder | Helper class for _ancestor |
TypeRecoveryHandler | |
SqlDatabase | Support for a variety of relational database drivers |
NoColumn | |
Exception | Exceptions thrown by database operations |
Connection | Connection to a database |
Transaction | Unit of work within a database |
Statement | A database operation |
iterator | Iterates over the result rows |
ColumnTraits | |
ColumnTraits< NoColumn > | |
Renderer | Renders a column value as a string |
Renderer< std::string > | |
AddrRenderer | Renders a rose_addr_t as a hexadecimal string |
TimeRenderer | Renders a time_t as a string |
PrePostRow | Called before and after printing each row of a table |
Header | |
Header< std::string > | |
Header< NoColumn > | |
RowSeparator | |
RowSeparator< NoColumn > | |
Table | In-memory representation of a database table |
Renderers | Functors for rendering column values |
Tuple | One row of a table |
ssa_private | |
CFG | A class holding a Control Flow Graph |
EdgeCopier | This class is used to copy edges when calling copy_graph() |
VertexCopier | This class is used to copy vertices when calling copy_graph() |
DataflowCfgFilter | Filter which determines which CFG nodes appear in the CFg used to propagate reaching definitions |
ChildUses | Attribute that describes the variables used by a given expression |
DefsAndUsesTraversal | This class collects all the defs and uses associated with each node in the traversed CFG |
FunctionFilter | This filter determines which function declarations get processed in the analysis |
VarUniqueName | Class holding a unique name for a variable |
VariableReferenceSet | Attribute that describes the variables modified by a given expression |
UniqueNameTraversal | Class to traverse the AST and assign unique names to every varRef |
ssa_unfiltered_cfg | |
ChildUses | Attribute that describes the variables used by a given expression |
DefsAndUsesTraversal | This class collects all the defs and uses associated with each node in the traversed CFG |
ReachingDef | |
FunctionFilter | This filter determines which function declarations get processed in the analysis |
SSA_UnfilteredCfg | |
StaticCFG | |
CustomFilteredCFG | A CFG implementation with Custom filters |
InterproceduralCFG | |
CFG | |
CFGNodeAttribute | This class stores index of each node as an attribuite of SgGraphNode |
CFGEdgeAttribute | |
DefaultFilter | |
InterestingCFGNodeFilter | |
ControlFlowGraph | |
EdgeCopier | This class is used to copy edges when calling copy_graph() |
VertexCopier | This class is used to copy vertices when calling copy_graph() |
StringUtility | |
StringWithLineNumber | |
FileNameClassification | |
varSets | |
VirtualBinCFG | |
AuxiliaryInformation | |
CFGNode | |
CFGEdge | |
VirtualCFG | |
FilteredCFGEdge | |
FilteredCFGNode | |
MakeClosure | |
CfgToDotImpl | |
CFGNode | A node in the control flow graph |
CFGEdge | A control flow edge connecting two CFG nodes, with an edge condition to indicate edge types |
CFGPath | |
InterestingNode | |
InterestingEdge | |
cfgRWTransaction | |
insertRequest | |
modRequest | |
transformRequest | |
DataflowNode | |
DataflowEdge | |
iterator | |
checkpoint | |
back_iterator | |
dataflow | |
checkpoint | |
back_dataflow | |
actionAnn | Action annotation |
actionChanger | Action changer |
Adaptor_Statistics | |
advanced_preprocessing_hooks | |
affineInequalitiesPlacer | |
affineInequality | |
affineInequalityFact | |
AliasCfgFilter | |
AliasInfoGenerator | Helper class to hold Alias Information |
AliasRelationNode | A struct to hold the information about an alias node |
always_true_predicate | Helper predicate for clearSuccessors function, always returns true |
Analysis | |
analyzeAnn | Analyze annotation |
Ann | Annotation base class |
Annotations | |
annVariable | Local variable |
arrayElt | |
Assembler | Virtual base class for instruction assemblers |
Exception | Exception thrown by the assemblers |
AssemblerX86 | This class contains methods for assembling x86 instructions (SgAsmx86Instruction) |
InsnDefn | Defines static characteristics of an instruction used by the assembler and disassembler |
Ast | This class allows to use iterators on the AST; it is different to the AstProcessing classes because no visit function needs to be implemented |
iterator | |
AST_FILE_IO | Class holding stat ic data and functions supporting File I/O |
MemoryCheckingTraversalForAstFileIO | |
AstAttribute | Base class for attributes that can be attached to AST nodes using the attribute mechanism in each AST node |
AttributeEdgeInfo | |
AttributeNodeInfo | |
AstAttributeMechanism | This mechanism provides capabilities to define a mapping from strings to AstAttributes. An instance of this class is accessible at each ROSE AST node in the data member 'attribute' |
AstBottomUpProcessing | Attribute Evaluator for synthesized attributes |
AstCombinedBottomUpProcessing | |
AstCombinedPrePostProcessing | |
AstCombinedSimpleProcessing | |
AstCombinedTopDownBottomUpProcessing | |
AstCombinedTopDownProcessing | |
AstCycleTest | AstCycleTest is based on the successor information of SgNodes (the same information that is used by the traversals) |
AstDOTGeneration | |
AstDOTGenerationExtended | |
AstInheritedAttribute | |
AstIntAttribute | |
AstNodePtrs | |
AstNodePtrSynAttr | |
AstNodeVisitMapping | |
AstParameterizedTypeAttribute | |
AstPDFGeneration | |
AstPreOrderTraversal | |
AstPrePostOrderTraversal | |
AstPrePostProcessing | |
AstRegExAttribute | Attribute corresponding to a regex expression |
AstRestructure | |
AstReverseBranchInhProcessing | |
AstReverseBranchInhSynProcessing | |
AstReverseBranchSimpleProcessing | |
AstReverseBranchSynProcessing | |
AstReversePrefixInhProcessing | |
AstReversePrefixInhSynProcessing | |
AstReversePrefixSimpleProcessing | |
AstReversePrefixSynProcessing | |
AstSgNodeAttribute | Attribute corresponding to an SgNode |
AstSgNodeListAttribute | |
AstSharedMemoryParallelBottomUpProcessing | |
AstSharedMemoryParallelBottomUpThreadArgs | |
AstSharedMemoryParallelizableBottomUpProcessing | |
AstSharedMemoryParallelizablePrePostProcessing | |
AstSharedMemoryParallelizableSimpleProcessing | |
AstSharedMemoryParallelizableTopDownBottomUpProcessing | |
AstSharedMemoryParallelizableTopDownProcessing | |
AstSharedMemoryParallelPrePostProcessing | |
AstSharedMemoryParallelProcessingSynchronizationBase | |
AstSharedMemoryParallelProcessingSynchronizationInfo | |
AstSharedMemoryParallelSimpleProcessing | |
AstSharedMemoryParallelTopDownBottomUpProcessing | |
AstSharedMemoryParallelTopDownBottomUpThreadArgs | |
AstSharedMemoryParallelTopDownProcessing | |
AstSharedMemoryParallelTopDownThreadArgs | |
AstSimpleProcessing | Class for traversing the AST |
AstSuccessorsSelectors | |
AstSynthesizedAttribute | |
AstTextAttribute | |
AstTextAttributesHandling | |
AstTopDownBottomUpProcessing | Attribute Evaluator for inherited and synthesized attributes |
AstTopDownProcessing | Attribute Evaluator for inherited attributes |
AttachAllPreprocessingInfoTreeTrav | |
AttachPreprocessingInfoTreeTrav | |
AttachPreprocessingInfoTreeTraversalInheritedAttrribute | |
AttachPreprocessingInfoTreeTraversalSynthesizedAttribute | |
AttributeListMap | |
findDirective | |
findDirectiveInList | |
BasicBlockLocalIndex | |
bdwyLivenessAnalyzer | Liveness analyzer |
BinaryLoader | Base class for loading a static or dynamic object |
Exception | Base class for exceptions thrown by loaders |
BinaryLoaderElf | |
SymbolMap | A mapping from symbol name (with optional version in parentheses) to SymbolMapEntry |
SymbolMapEntry | An entry for a SymbolMap |
SymverResolver | |
VersionedSymbol | Symbol from .dynsym combined with additional information |
BinaryLoaderElfObj | A loader suitable for ELF object files |
BinaryLoaderPe | |
bindingReportElementAnn | Binding report element |
BoolAndLattice | |
BooleanSafeKeeper | |
Bot | |
BottomUpTraversalLivenessIN | |
BottomUpTraversalLivenessOUT | |
Broadway | |
builtinFilter | A function object to filter out builtin functions in a call graph (only non-builtin functions will be considered) |
Callgraph | Callgraph, implemented with a boost graph |
CallGraphBuilder | |
CallgraphInhAttr | |
CallgraphTraversal | |
callgraphVertexData | |
callingContext | |
cgData | |
cgEdge | |
CGFunction | |
iterator | |
cgNode | |
ChainableTypeLayoutGenerator | Basic type layout engine – handles bookkeeping, plus handing typedefs and |
CheckWhichAreMarked | |
chVertexData | |
Classhierarchy | Class hierarchy does not have multiple edges, so "setS" is used as vertex list |
ClasshierarchyInhAttr | |
ClasshierarchyTraversal | |
ClassHierarchyWrapper | |
CollectAliasRelations | Helper class to collect Alias Relations |
CollectFunctions | |
CompactRepresentation | |
compareSgGraphNode | |
CompReprBase | |
CompReprPtr | A Shared Pointer Wrapper for CompactRepresentation |
connectiveExprAnn | Boolean connective expression |
constantProp | |
ConstrGraph | |
geIterator | |
leIterator | |
NodeDesc | |
ConstrGraphAnalysis | |
ContextInsensitiveInterProceduralDataflow | |
ContextVis_R | Strategy pattern applied to visitors: serves as a context to a strategy, which itself is a visitor; delegates all requests to the current strategy; capable of switching strategy at will |
ControlDependenceGraph | |
CppToCppTranslator | Default Cpp2Cpp Translator |
CppToDotTranslator | |
CppToPdfTranslator | |
CppToVendorTranslator | |
CreateSlice | |
CreateSliceSet | |
CustomizedPrimitiveTypeLayoutGenerator | Layout generator for customized primitive types, mostly for UPC relying on Berkeley runtime library now |
DatabaseGraph | Graph database storage class |
DataConverter | Encodes and decodes a buffer using an algorithm defined in subclasses |
DataDependenceGraph | |
DataFlowAnalysis | |
DataFlowNode | |
dbRow | |
dbTable | |
DDE_data | |
DefaultDUchain | |
DefUseAnalysis | |
DefUseAnalysisAbstract | |
DefUseAnalysisPF | |
DefUseChain | |
DefUseChainNode | |
deleteDFAnalysisState | |
DependenceGraph | |
DependenceNode | |
DFAnalysis | |
DFStateAtReturns | |
Diagnostic | A data structure used for tracing in error disgnostic |
Disassembler | Virtual base class for instruction disassemblers |
Exception | Exception thrown by the disassemblers |
DisassemblerArm | Disassembler for the ARM architecture |
ExceptionArm | Same as Disassembler::Exception except with a different constructor for ease of use in DisassemblerArm |
DisassemblerMips | |
Mips32 | Interface for disassembling a single instruction |
DisassemblerPowerpc | Disassembler for the PowerPC architecture |
ExceptionPowerpc | Same as Disassembler::Exception except with a different constructor for ease of use in DisassemblerPowerpc |
DisassemblerX86 | Disassembler for the x86 architecture |
ExceptionX86 | Same as Disassembler::Exception except with a different constructor for ease of use in DisassemblerX86 |
DistributedMemoryAnalysisPostTraversal | |
DistributedMemoryAnalysisPreTraversal | |
DivAnalysis | |
DivAnalysisTransfer | |
DivLattice | |
DominatorAnalysis | |
DominatorLattice | |
DOTGeneration | This class defines the DOT output (graphical representation) of the AST |
DOTInheritedAttribute | This class defines the DOT output (graphical representation) of the AST |
DOTRepresentation | This class defines the DOT output (graphical representation) of the AST |
DOTSynthesizedAttribute | This class defines the DOT output (graphical representation) of the AST |
dottable | |
dummyFilter | A function object to be used as a predicate to filter out functions in a call graph: it does not filter out anything |
EasyStorage | |
ECR | |
ECRmap | |
VariableAlreadyDefined | |
EDefUse | |
Edge | |
Edge2 | |
enumPropertyAnn | A dataflow analysis property |
enumPropertyExprAnn | Property test expression |
enumvalue_set | |
enumValueAnn | A dataflow analysis lattice element |
eqstr | Name equality operator support for symbol tables within ROSE |
exprAnn | Expression base class |
expressionReportElementAnn | Expression report element |
exprPatternNode | |
ExtentMap | |
ExtractFunctionArguments | This normalization makes sure each function call argument is a side-effect free expression of only one variable |
file_pos_info | |
FindAllFunctionCalls | |
FindAllNodesAnalysis | |
FindDefUseChainNode | |
FindStatements | |
FiniteLattice | |
FiniteProductLattice | |
FiniteVariablesProductLattice | |
FiniteVarsExprsProductLattice | |
FormatRestorer | Restores output stream flags to original values |
funcSideEffectUses | |
Function | |
FunctionCallInfo | Stores a function call expression, along with associated information about its context |
FunctionCallInheritedAttribute | |
FunctionData | |
FunctionDependenceGraph | |
FunctionEvaluationOrderTraversal | Traverses a given AST and finds all function calls in the order in which they're evaluated Also, for each function we find where to put declarations of temporary variables so that they're accessible at the function call |
FunctionNames | |
FunctionNamesPostTraversal | |
FunctionNamesPreTraversal | |
FunctionState | |
generateDOTExtended | |
generateDOTExtended_withIncludes | |
generateDOTExtendedforMultipleFile | |
genUID | |
GetOneFuncDeclarationPerFunction | |
GlobalIndex | |
GlobalIndexing | |
GlobalVarAnalysis | |
hash_Name | Hash name support for symbol tables within ROSE |
HasValueCodeGen | |
HasValueCollection | |
HasValueDescriptor | |
HasValueMap | |
HasValueMapReplace | |
HexdumpFormat | Settings that control how the lowest-level SgAsmExecutableFileFormat::hexdump function behaves |
I386_VSPrimitiveTypeLayoutGenerator | Slight modification for Visual Studio – doubles are 8-byte aligned |
I386PrimitiveTypeLayoutGenerator | Layout generator for i386 primitive types |
IncludeDirective | |
InfiniteLattice | |
InfiniteProductLattice | |
InfiniteVariablesProductLattice | |
InfiniteVarsExprsProductLattice | |
InitDataflowState | |
InsertPragma | |
IntArithLogical | |
exprLeaf | |
exprLeafOrNode | |
logicNode | |
IntArithLogicalFact | |
IntArithLogicalPlacer | |
InterProcDataFlowAnalysis | |
InterProceduralAnalysis | |
InterProceduralDataflow | |
InterproceduralInfo | |
CallSiteStructure | |
IntMaxLattice | |
IntraBWDataflow | |
IntraDFTransferVisitor | Apply an analysis A's transfer function at a particular AST node type |
IntraFWDataflow | |
IntraPartitionDataflow | |
IntraPartitionDataflowCheckpoint | |
IntraPartitionFWDataflow | |
IntraProcAliasAnalysis | IntraProcedurial DataFlow Analysis to compute exit and entry from all the function which |
IntraProcDataFlowAnalysis | |
IntraProceduralAnalysis | |
IntraProceduralDataflow | |
IntraUniDirectionalDataflow | |
IntraUnitDataflow | |
DefaultTransfer | |
ipConstant | |
IsDefUseFilter | Struct containing a filtering function to determine what CFG nodes are interesting during the DefUse traversal |
IsDFAFilter | |
IsImportantForSliceCFGFilter | |
KeepAttribute | |
Lambda | |
Lattice | |
LinearCongruentialGenerator | Linear congruential generator |
literalReportElementAnn | Literal string report element |
LiveDeadVarsAnalysis | |
LiveDeadVarsTransfer | |
LivenessAnalysis | |
LiveVarsLattice | |
locationReportElementAnn | Location report element |
LogicalCond | |
MarkAll | |
MarkingNodes | |
MemoryMap | An efficient mapping from an address space to stored data |
AnonymousBuffer | Buffer of bytes |
Buffer | Base class for data associated with a memory segment |
ByteBuffer | Buffer of bytes |
Exception | Exception for MemoryMap operations |
ExternBuffer | Buffer of data owned by someone else |
Inconsistent | Exception for an inconsistent mapping |
MmapBuffer | Buffer whose underlying storage is from mmap |
NoFreeSpace | Exception thrown by find_free() when there's not enough free space left |
NotMapped | Exception for when we try to access a virtual address that isn't mapped |
NullBuffer | Buffer that has no data |
Segment | A contiguous, homogeneous region of an address space |
SyntaxError | Exception thrown by load() when there's a syntax error in the index file |
Visitor | Visitor for traversing a memory map |
MergeAllReturnStates | |
MergedDependenceGraph | |
MetricAttribute | Attribute corresponding to a metric |
mutex | |
MyAnalysis | |
nodeConstAnalysis | |
nodeConstLattice | |
NodeFact | |
NodeID | |
NodeState | |
NonpackedTypeLayoutGenerator | Layout generator for i386 ABI-like struct layout |
numCallersAttribute | |
numericExprAnn | Numeric expression |
OptionDeclaration | This class is part of the specification of transformation options |
parserID | Parser identifier class |
partitionDFAnalysisState | |
PartitionedAnalysis | |
Partitioner | Partitions instructions into basic blocks and functions |
AbandonFunctionDiscovery | Exception thrown to defer function block discovery |
BasicBlock | Represents a basic block within the Partitioner |
BlockAnalysisCache | Analysis that can be cached in a block |
BlockConfig | Basic block configuration information |
ByteRangeCallback | Base class for byte scanning callbacks |
Args | Arguments for the callback |
CodeCriteria | Criteria to decide whether a region of memory contains code |
Criterion | |
DictionaryEntry | |
DataBlock | Represents a region of static data within the address space being disassembled |
DataRangeMapValue | Value type for DataRangeMap |
Exception | |
FindData | Callback to add unassigned addresses to a function |
FindDataPadding | Callback to detect padding |
FindFunctionFragments | Callback to insert unreachable code fragments |
FindInsnPadding | Callback to create inter-function instruction padding |
FindInterPadFunctions | Callback to find functions that are between padding |
FindPostFunctionInsns | Callback to add post-function instructions to the preceding function |
FindThunks | Callback to find thunks |
FindThunkTables | Callback to find thunk tables |
Function | Represents a function within the Partitioner |
FunctionRangeMapValue | Value type for FunctionRangeMap |
FunctionStart | Information about each function starting address |
InsnRangeCallback | Base class for instruction scanning callbacks |
Args | Arguments for the callback |
Instruction | Holds an instruction along with some other information about the instruction |
IPDParser | This is the parser for the instruction partitioning data (IPD) files |
Exception | Exception thrown when something cannot be parsed |
RegionStats | Statistics computed over a region of an address space |
AnalysisResult | |
DictionaryEntry | |
partSplit | |
patternExpander | |
PDFGeneration | This class defines the PDF output of the AST |
PDFInheritedAttribute | This class defines the PDF output (graphical representation) of the AST |
placeUniqueIDs | |
pointerExprAnn | Pointer test expression |
pointerRuleAnn | Pointer analysis rule |
PreprocessingInfo | For preprocessing information including source comments, #include , #if, #define, etc |
r_include_directive | |
r_macro_def | |
rose_macro_call | |
printable | |
printAnalysisStates | |
printDataflowInfoPass | |
procedureAnn | Procedure annotation |
ProductLattice | |
ProgramVerifier | |
projectsRow | |
propertyAnn | A dataflow analysis property |
PtrAliasAnalysis | PtrAliasAnalysis computes Alias Information, which is used for Virtual Function Resolving |
PtrAnal | |
hash | |
VarRef | |
Range | A contiguous range of values |
RangeMap | A container of ranges, somewhat like a set |
RangeCompare | The value attached to each range in this RangeMap |
RangeMapNumeric | Scalar value type for a RangeMap |
RangeMapValue | Scalar value type for a RangeMap |
RangeMapVoid | Value type for a RangeMap with no useful data attached to the ranges |
ReachingDef | |
ReachingDefinitionAnalysis | |
ReachingDefinitionBase | |
ReachingDefinitionFacade | |
ReachingDefinitionGenerator | |
ReachingDefNode | |
RegisterDescriptor | Describes (part of) a physical CPU register |
RegisterDictionary | Defines registers available for a particular architecture |
SortBySize | Compares number of bits in register descriptors |
RegisterNames | Prints a register name even when no dictionary is available or when the dictionary doesn't contain an entry for the specified descriptor |
RemovalOfNodes | |
reportAnn | Report annotation |
reportElementAnn | Report element base class |
RestrictValueOpCollection | |
RestrictValueOpDescriptor | |
ROSE_BaseGrammar | |
rose_graph_integer_edge_hash_map | |
rose_graph_integer_edge_hash_multimap | |
rose_graph_integer_node_hash_map | |
rose_graph_integerpair_edge_hash_multimap | |
rose_graph_node_edge_hash_multimap | |
rose_graph_string_integer_hash_multimap | |
rose_graph_string_node_hash_multimap | |
rose_hash_multimap | Hash table support for symbol tables within ROSE |
rose_rva_t | A relative virtual address optionally associated with a SgAsmSection |
ROSE_VisitorPattern | |
ROSE_VisitorPatternDefaultBase | |
ROSE_VisitTraversal | |
ROSEAttributesList | |
ROSEAttributesListContainer | |
RoseBin_DotGraph | |
RoseBin_GMLGraph | |
RoseBin_Graph | |
RoseSrc_CallGraphAnalysis | |
RoseTestTranslator | |
Rot13 | The ROT-13 algorithm, extended to operate over the entire 8-bit domain/range |
RTIMemberData | Access to C++ Run Time Information (RTI) |
RTS_Message | Support for messages in a multi-threaded program |
Prefix | Used to generate prefix text for every line of output |
RTS_mutex_t | Mutual exclusion lock |
RTS_rwlock_t | A read-write lock for ROSE Thread Support |
ruleAnn | Analysis rule annotation |
SaveDotAnalysis | |
SB_CallGraph | |
SB_DirectedGraph | |
SDGLibraryExtender | |
SeqStructAnalysis | |
SeqStructLattice | |
setPropertyAnn | |
setPropertyExprAnn | Set property expression |
Sg_File_Info | This class represents the location of the code associated with the IR node in the original source code |
SgAccessModifier | |
SgActualArgumentExpression | |
SgAddOp | |
SgAddressOfOp | |
SgAggregateInitializer | This class represents the rhs of an array variable declaration which includes an optional assignment (e.g. "int x[2] = {1,2};"). In this case the SgExprListExp ("{1,2}") is wrapped in an SgAggregateInitializer |
SgAliasSymbol | |
SgAlignOfOp | |
SgAllocateStatement | |
SgAndAssignOp | |
SgAndOp | |
SgArithmeticIfStatement | |
SgArrayType | |
SgArrowExp | |
SgArrowStarOp | |
SgAsmArmInstruction | |
SgAsmArmRegisterReferenceExpression | |
SgAsmBasicString | |
SgAsmBinaryAdd | |
SgAsmBinaryAddPostupdate | |
SgAsmBinaryAddPreupdate | |
SgAsmBinaryAddressSymbol | |
SgAsmBinaryAsr | |
SgAsmBinaryDataSymbol | |
SgAsmBinaryDivide | |
SgAsmBinaryExpression | |
SgAsmBinaryLsl | |
SgAsmBinaryLsr | |
SgAsmBinaryMod | |
SgAsmBinaryMultiply | |
SgAsmBinaryRor | |
SgAsmBinarySubtract | |
SgAsmBinarySubtractPostupdate | |
SgAsmBinarySubtractPreupdate | |
SgAsmBlock | |
SgAsmCoffStrtab | |
SgAsmCoffSymbol | |
COFFSymbol_disk | |
SgAsmCoffSymbolList | |
SgAsmCoffSymbolTable | |
SgAsmCommonSubExpression | |
SgAsmControlFlagsExpression | |
SgAsmDOSExtendedHeader | |
DOSExtendedHeader_disk | |
SgAsmDOSFileHeader | |
DOSFileHeader_disk | |
DOSRelocEntry_disk | |
SgAsmDoubleFloatValueExpression | |
SgAsmDwarfAccessDeclaration | |
SgAsmDwarfArrayType | |
SgAsmDwarfBaseType | |
SgAsmDwarfCatchBlock | |
SgAsmDwarfClassTemplate | |
SgAsmDwarfClassType | |
SgAsmDwarfCommonBlock | |
SgAsmDwarfCommonInclusion | |
SgAsmDwarfCompilationUnit | |
SgAsmDwarfCompilationUnitList | |
SgAsmDwarfCondition | |
SgAsmDwarfConstant | |
SgAsmDwarfConstruct | |
SgAsmDwarfConstructList | |
SgAsmDwarfConstType | |
SgAsmDwarfDwarfProcedure | |
SgAsmDwarfEntryPoint | |
SgAsmDwarfEnumerationType | |
SgAsmDwarfEnumerator | |
SgAsmDwarfFileType | |
SgAsmDwarfFormalParameter | |
SgAsmDwarfFormatLabel | |
SgAsmDwarfFriend | |
SgAsmDwarfFunctionTemplate | |
SgAsmDwarfImportedDeclaration | |
SgAsmDwarfImportedModule | |
SgAsmDwarfImportedUnit | |
SgAsmDwarfInformation | |
SgAsmDwarfInheritance | |
SgAsmDwarfInlinedSubroutine | |
SgAsmDwarfInterfaceType | |
SgAsmDwarfLabel | |
SgAsmDwarfLexicalBlock | |
SgAsmDwarfLine | |
SgAsmDwarfLineList | |
SgAsmDwarfMacro | |
SgAsmDwarfMacroList | |
SgAsmDwarfMember | |
SgAsmDwarfModule | |
SgAsmDwarfMutableType | |
SgAsmDwarfNamelist | |
SgAsmDwarfNamelistItem | |
SgAsmDwarfNamespace | |
SgAsmDwarfPackedType | |
SgAsmDwarfPartialUnit | |
SgAsmDwarfPointerType | |
SgAsmDwarfPtrToMemberType | |
SgAsmDwarfReferenceType | |
SgAsmDwarfRestrictType | |
SgAsmDwarfSetType | |
SgAsmDwarfSharedType | |
SgAsmDwarfStringType | |
SgAsmDwarfStructureType | |
SgAsmDwarfSubprogram | |
SgAsmDwarfSubrangeType | |
SgAsmDwarfSubroutineType | |
SgAsmDwarfTemplateTypeParameter | |
SgAsmDwarfTemplateValueParameter | |
SgAsmDwarfThrownType | |
SgAsmDwarfTryBlock | |
SgAsmDwarfTypedef | |
SgAsmDwarfUnionType | |
SgAsmDwarfUnknownConstruct | |
SgAsmDwarfUnspecifiedParameters | |
SgAsmDwarfUnspecifiedType | |
SgAsmDwarfUpcRelaxedType | |
SgAsmDwarfUpcSharedType | |
SgAsmDwarfUpcStrictType | |
SgAsmDwarfVariable | |
SgAsmDwarfVariant | |
SgAsmDwarfVariantPart | |
SgAsmDwarfVolatileType | |
SgAsmDwarfWithStmt | |
SgAsmElfDynamicEntry | |
Elf32DynamicEntry_disk | |
Elf64DynamicEntry_disk | |
SgAsmElfDynamicEntryList | |
SgAsmElfDynamicSection | |
SgAsmElfEHFrameEntryCI | |
SgAsmElfEHFrameEntryCIList | |
SgAsmElfEHFrameEntryFD | |
SgAsmElfEHFrameEntryFDList | |
SgAsmElfEHFrameSection | |
SgAsmElfFileHeader | |
Elf32FileHeader_disk | |
Elf64FileHeader_disk | |
SgAsmElfNoteEntry | |
SgAsmElfNoteEntryList | |
SgAsmElfNoteSection | |
SgAsmElfRelocEntry | |
Elf32RelaEntry_disk | |
Elf32RelEntry_disk | |
Elf64RelaEntry_disk | |
Elf64RelEntry_disk | |
SgAsmElfRelocEntryList | |
SgAsmElfRelocSection | |
SgAsmElfSection | |
SgAsmElfSectionTable | |
SgAsmElfSectionTableEntry | |
Elf32SectionTableEntry_disk | File format of an ELF Section header |
Elf64SectionTableEntry_disk | |
SgAsmElfSegmentTable | |
SgAsmElfSegmentTableEntry | |
Elf32SegmentTableEntry_disk | |
Elf64SegmentTableEntry_disk | |
SgAsmElfSegmentTableEntryList | |
SgAsmElfStringSection | |
SgAsmElfStrtab | |
SgAsmElfSymbol | |
Elf32SymbolEntry_disk | |
Elf64SymbolEntry_disk | |
SgAsmElfSymbolList | |
SgAsmElfSymbolSection | |
SgAsmElfSymverDefinedAux | |
ElfSymverDefinedAux_disk | Elfxx_Verdaux, Note: same for 32bit and 64bit |
SgAsmElfSymverDefinedAuxList | |
SgAsmElfSymverDefinedEntry | |
ElfSymverDefinedEntry_disk | Elfxx_Verdef, Note, same for 32bit and 64bit |
SgAsmElfSymverDefinedEntryList | |
SgAsmElfSymverDefinedSection | |
SgAsmElfSymverEntry | |
SgAsmElfSymverEntryList | |
SgAsmElfSymverNeededAux | |
ElfSymverNeededAux_disk | Elfxx_Verdaux, Note: same for 32bit and 64bit |
SgAsmElfSymverNeededAuxList | |
SgAsmElfSymverNeededEntry | |
ElfSymverNeededEntry_disk | Elfxx_Verneed, Note, same for 32bit and 64bit |
SgAsmElfSymverNeededEntryList | |
SgAsmElfSymverNeededSection | |
SgAsmElfSymverSection | |
SgAsmExecutableFileFormat | |
FormatError | |
ShortRead | |
ShortWrite | |
SgAsmExpression | |
SgAsmExprListExp | |
SgAsmFunction | |
NodeSelector | Selection functor for SgAsmFunction::get_extent() |
SgAsmGenericDLL | |
SgAsmGenericDLLList | |
SgAsmGenericFile | |
SgAsmGenericFileList | |
SgAsmGenericFormat | |
SgAsmGenericHeader | |
SgAsmGenericHeaderList | |
SgAsmGenericSection | The SgAsmGenericSection represents any contiguous region of a file that serves a particular purpose |
SgAsmGenericSectionList | |
SgAsmGenericString | |
SgAsmGenericStrtab | |
SgAsmGenericSymbol | |
SgAsmGenericSymbolList | |
SgAsmInstruction | |
SgAsmIntegerValueExpression | Base class for integer values |
SgAsmInterpretation | |
SgAsmInterpretationList | |
SgAsmLEEntryPoint | |
LEEntryPoint_disk | |
SgAsmLEEntryTable | |
SgAsmLEFileHeader | |
LEFileHeader_disk | |
SgAsmLENameTable | |
SgAsmLEPageTable | |
SgAsmLEPageTableEntry | |
LEPageTableEntry_disk | |
SgAsmLERelocTable | |
SgAsmLESection | |
SgAsmLESectionTable | |
SgAsmLESectionTableEntry | |
LESectionTableEntry_disk | |
SgAsmMemoryReferenceExpression | |
SgAsmMipsInstruction | |
SgAsmMipsRegisterReferenceExpression | |
SgAsmNEEntryPoint | |
SgAsmNEEntryTable | |
SgAsmNEFileHeader | |
NEFileHeader_disk | |
SgAsmNEModuleTable | |
SgAsmNENameTable | |
SgAsmNERelocEntry | |
iname_type | |
iord_type | |
iref_type | |
osfixup_type | |
SgAsmNERelocTable | |
SgAsmNESection | |
SgAsmNESectionTable | |
SgAsmNESectionTableEntry | |
NESectionTableEntry_disk | |
SgAsmNEStringTable | |
SgAsmNode | |
SgAsmOp | |
SgAsmOperandList | |
SgAsmPEExportDirectory | |
PEExportDirectory_disk | |
SgAsmPEExportEntry | |
SgAsmPEExportEntryList | |
SgAsmPEExportSection | |
SgAsmPEFileHeader | |
PE32OptHeader_disk | |
PE64OptHeader_disk | |
PEFileHeader_disk | |
SgAsmPEImportDirectory | Portable Executable Import Directory |
PEImportDirectory_disk | |
SgAsmPEImportDirectoryList | |
SgAsmPEImportItem | Portable Executable Import Object |
SgAsmPEImportItemList | |
SgAsmPEImportSection | Portable Executable Import Section. |
SgAsmPERVASizePair | |
RVASizePair_disk | |
SgAsmPERVASizePairList | |
SgAsmPESection | |
SgAsmPESectionTable | |
SgAsmPESectionTableEntry | |
PESectionTableEntry_disk | |
SgAsmPEStringSection | |
SgAsmPowerpcInstruction | |
SgAsmPowerpcRegisterReferenceExpression | |
SgAsmRegisterReferenceExpression | |
SgAsmSingleFloatValueExpression | |
SgAsmStatement | |
SgAsmStaticData | |
SgAsmStmt | This class represents the concept of a C Assembler statement |
SgAsmStoredString | |
SgAsmStringStorage | |
SgAsmSynthesizedDataStructureDeclaration | |
SgAsmSynthesizedDeclaration | |
SgAsmSynthesizedFieldDeclaration | |
SgAsmType | |
SgAsmType128bitFloat | |
SgAsmType80bitFloat | |
SgAsmTypeByte | |
SgAsmTypeDoubleFloat | |
SgAsmTypeDoubleQuadWord | |
SgAsmTypeDoubleWord | |
SgAsmTypeQuadWord | |
SgAsmTypeSingleFloat | |
SgAsmTypeVector | |
SgAsmTypeWord | |
SgAsmUnaryArmSpecialRegisterList | |
SgAsmUnaryExpression | |
SgAsmUnaryMinus | |
SgAsmUnaryPlus | |
SgAsmUnaryRrx | |
SgAsmValueExpression | Assembly operands that contain numeric values |
SgAsmx86Instruction | |
SgAsmx86RegisterReferenceExpression | |
SgAssertStmt | |
SgAssignedGotoStatement | |
SgAssignInitializer | This class represents the rhs of a variable declaration which includes an optional assignment (e.g. "int x = 1;"). In this case the SgValue ("1") is wrapped in an SgAssignInitializer |
SgAssignOp | |
SgAssignStatement | |
SgAssociateStatement | |
SgAsteriskShapeExp | |
SgAterm | |
SgAttribute | |
SgAttributeSpecificationStatement | |
SgBackspaceStatement | |
SgBaseClass | |
SgBaseClassModifier | |
SgBasicBlock | This class represents the concept of a block (not a basic block from control flow analysis) |
SgBidirectionalGraph | |
SgBinaryComposite | |
SgBinaryNode | This class represents the base class for all IR nodes supporting the binary representation of software within Sage III |
SgBinaryOp | This class represents the notion of a binary operator. It is derived from a SgExpression because operators are expressions |
SgBitAndOp | |
SgBitAttribute | |
SgBitComplementOp | |
SgBitOrOp | |
SgBitXorOp | |
SgBlockDataStatement | |
SgBoolValExp | This class represents a boolean value (expression value) |
SgBottomUpProcessing | |
SgBreakStmt | This class represents the notion of a break statement (typically used in a switch statment) |
SgC_PreprocessorDirectiveStatement | |
SgCAFCoExpression | |
SgCAFWithTeamStatement | |
SgCallExpression | This class represents the concept of a generic call expression |
SgCapturingCopy | Supporting template class for "capturing" copies of the AST |
SgCaseOptionStmt | This class represents the concept of a C and C++ case option (used within a switch statement) |
SgCastExp | |
SgCatchOptionStmt | This class represents the concept of a catch within a try-catch construct used in C++ exception handling |
SgCatchStatementSeq | This class represents the concept of a C++ sequence of catch statements |
SgCharVal | |
SgClassDecl_attr | |
SgClassDeclaration | This class represents the concept of a class declaration statement. It includes the concept of an instantiated class template as well |
SgClassDefinition | This class represents the concept of a class definition in C++ |
SgClassExp | |
SgClassNameRefExp | This class represents the concept of a C++ expression built from a class name |
SgClassSymbol | This class represents the concept of a class name within the compiler |
SgClassType | |
SgClinkageDeclarationStatement | |
SgClinkageEndStatement | |
SgClinkageStartStatement | This class represents the concept of a C style "extern \"C" " declaration. But such information (linkage) is stored within linkage modifiers currently |
SgCloseStatement | |
SgColonShapeExp | |
SgCombinedTreeTraversal | |
SgCommaOpExp | |
SgCommonBlock | |
SgCommonBlockObject | |
SgCommonSymbol | |
SgComplexVal | |
SgCompoundAssignOp | |
SgCompoundInitializer | |
SgCompoundLiteralExp | |
SgComprehension | |
SgComputedGotoStatement | |
SgConcatenationOp | |
SgConditionalExp | This class represents the concept of a C trinary conditional expression (e.g. "test ? true : false") |
SgConjugateOp | |
SgConstructorInitializer | This class represents the notion of an initializer for a variable declaration or expression in a function call argument list |
SgConstVolatileModifier | |
SgContainsStatement | |
SgContinueStmt | This class represents the concept of a C or C++ continue statement |
SgCopyHelp | Supporting class from copy mechanism within ROSE |
SgCtorInitializerList | This class represents the concept of a contructor initializer list (used in constructor (member function) definitions) |
SgCudaKernelCallExp | |
SgCudaKernelExecConfig | |
SgDataStatementGroup | |
SgDataStatementObject | |
SgDataStatementValue | |
SgDeadIfDirectiveStatement | |
SgDeallocateStatement | |
SgDeclarationModifier | This class represents modifiers for SgDeclaration (declaration statements) |
SgDeclarationStatement | This class represents the concept of a declaration statement |
SgDefaultOptionStmt | This class represents the concept of a C or C++ default case within a switch statement |
SgDefaultSymbol | |
SgDefineDirectiveStatement | |
SgDeleteExp | This class represents the concept of a C++ call to the delete operator |
SgDerivedTypeStatement | |
SgDesignatedInitializer | |
SgDictionaryComprehension | |
SgDictionaryExp | |
SgDimensionObject | |
SgDirectedGraphEdge | |
SgDirectory | This class represents a directory within a projects file structure of files and directories |
SgDirectoryList | |
SgDivAssignOp | |
SgDivideOp | |
SgDotExp | |
SgDotStarOp | |
SgDoubleVal | This class represents the notion of an value (expression value) |
SgDoWhileStmt | This class represents the concept of a do-while statement |
SgElaboratedTypeModifier | |
SgElseDirectiveStatement | |
SgElseifDirectiveStatement | |
SgElseWhereStatement | |
SgEmptyDirectiveStatement | |
SgEndfileStatement | |
SgEndifDirectiveStatement | |
SgEntryStatement | |
SgEnumDeclaration | This class represents the concept of an enum declaration |
SgEnumFieldSymbol | |
SgEnumSymbol | |
SgEnumType | |
SgEnumVal | |
SgEqualityOp | |
SgEquivalenceStatement | |
SgErrorDirectiveStatement | |
SgExecStatement | This class represents the concept of the dynamic execution of a string, file, or code object. This node is intended for use with Python |
SgExpBaseClass | |
SgExponentiationAssignOp | |
SgExponentiationOp | |
SgExpression | This class represents the notion of an expression. Expressions are derived from SgLocatedNodes, since similar to statement, expressions have a concrete location within the user's source code |
SgExpressionRoot | |
SgExprListExp | This class represents the concept of a C and C++ expression list |
SgExprStatement | This class represents the concept of a C or C++ statement which contains a expression |
SgFile | This class represents a source file for a project (which may contian many source files and or directories) |
SgFileList | |
SgFloatVal | This class represents the notion of an value (expression value) |
SgFlushStatement | |
SgForAllStatement | |
SgForInitStatement | This class represents the variable declaration or variable initialization withn a for loop |
SgFormatItem | |
SgFormatItemList | |
SgFormatStatement | |
SgForStatement | This class represents the concept of a for loop |
SgFortranDo | |
SgFortranIncludeLine | |
SgFortranNonblockedDo | |
SgFuncDecl_attr | |
SgFunctionCallExp | This class represents the concept of a C++ function call (which is an expression) |
SgFunctionDeclaration | This class represents the concept of a function declaration statement |
SgFunctionDefinition | This class represents the concept of a scope in C++ (e.g. global scope, fuction scope, etc.) |
SgFunctionModifier | |
opencl_work_group_size_t | |
SgFunctionParameterList | This class represents the concept of a declaration list |
SgFunctionParameterTypeList | |
SgFunctionRefExp | This class represents the function being called and must be assembled in the SgFunctionCall with the function arguments |
SgFunctionSymbol | |
SgFunctionType | This class represents a type for all functions |
SgFunctionTypeSymbol | |
SgFunctionTypeTable | This class represents the function type table (stores all function types so that they can be shared internally) |
SgGlobal | This class represents the concept of a namespace definition |
SgGotoStatement | This class represents the concept of a C or C++ goto statement |
SgGraph | |
SgGraphEdge | |
SgGraphEdgeList | |
SgGraphNode | |
SgGraphNodeList | |
SgGraphTraversal | |
SgGreaterOrEqualOp | |
SgGreaterThanOp | |
SgHeaderFileBody | |
SgIdentDirectiveStatement | |
SgIfdefDirectiveStatement | |
SgIfDirectiveStatement | |
SgIfndefDirectiveStatement | |
SgIfStmt | This class represents the concept of an "if" construct |
SgImagPartOp | |
SgImplicitStatement | |
SgImpliedDo | |
SgImportStatement | |
SgIncidenceDirectedGraph | |
SgIncidenceUndirectedGraph | |
SgIncludeDirectiveStatement | |
SgIncludeNextDirectiveStatement | |
SgInheritedAttribute | |
SgInitializedName | This class represents the notion of a declared variable |
SgInitializer | This class represents the notion of an initializer for a variable declaration or expression in a function call argument list |
SgInquireStatement | |
SgIntegerDivideAssignOp | |
SgIntegerDivideOp | |
SgInterfaceBody | |
SgInterfaceStatement | |
SgInterfaceSymbol | |
SgIntKeyedBidirectionalGraph | |
SgIntrinsicSymbol | |
SgIntVal | |
SgIOItemExpression | |
SgIorAssignOp | |
SgIOStatement | |
SgIsNotOp | This class represents the physical disequality (often called pointer disequality) operator for languages that also define a content disequality operator |
SgIsOp | This class represents the physical equality (often called pointer equality) operator for languages that also define a content equality operator |
SgJavaAnnotation | |
SgJavaClassDeclarationList | |
SgJavaForEachStatement | |
SgJavaImportStatement | |
SgJavaImportStatementList | |
SgJavaInstanceOfOp | |
SgJavaLabelStatement | |
SgJavaLabelSymbol | |
SgJavaMarkerAnnotation | |
SgJavaMemberValuePair | |
SgJavaNormalAnnotation | |
SgJavaPackageDeclaration | |
SgJavaPackageStatement | |
SgJavaParameterizedType | |
SgJavaParameterType | |
SgJavaQualifiedType | |
SgJavaSingleMemberAnnotation | |
SgJavaSynchronizedStatement | |
SgJavaThrowStatement | |
SgJavaTypeExpression | |
SgJavaUnionType | |
SgJavaUnsignedRshiftAssignOp | |
SgJavaUnsignedRshiftOp | |
SgJavaWildcardType | |
SgKeyDatumPair | |
SgLabelRefExp | |
SgLabelStatement | This class represents the concept of a C or C++ label statement |
SgLabelSymbol | |
SgLambdaRefExp | This class represents a lambda expression |
SgLessOrEqualOp | |
SgLessThanOp | |
SgLineDirectiveStatement | |
SgLinemarkerDirectiveStatement | |
SgLinkageModifier | |
SgListComprehension | |
SgListExp | This class represents a list display |
SgLocatedNode | This class represents the notion of an expression or statement which has a position within the source code |
SgLocatedNodeSupport | |
SgLongDoubleVal | This class represents the notion of an value (expression value) |
SgLongIntVal | |
SgLongLongIntVal | |
SgLshiftAssignOp | |
SgLshiftOp | |
SgMemberFunctionDeclaration | This class represents the concept of a member function declaration statement |
SgMemberFunctionRefExp | This class represents the member function being called and must be assembled in the SgFunctionCall with the function arguments |
SgMemberFunctionSymbol | |
SgMemberFunctionType | |
SgMembershipOp | |
SgMinusAssignOp | |
SgMinusMinusOp | |
SgMinusOp | This class represents the numeric negation of a value. Not to be confused with SgSubtractOp |
SgModAssignOp | |
SgModifier | This class represents the base class of a number of IR nodes define modifiers within the C++ grammar |
SgModifierNodes | This class represents a list of SgModifierTypes and a link is a linked list of SgModifierNodes |
SgModifierType | |
SgModOp | |
SgModuleStatement | |
SgModuleSymbol | |
SgMultAssignOp | |
SgMultiplyOp | |
SgName | This class represents strings within the IR nodes |
SgNamedType | |
SgNameGroup | |
SgNamelistStatement | |
SgNamespaceAliasDeclarationStatement | This class represents the concept of a C++ namespace alias declaration statement |
SgNamespaceDeclarationStatement | This class represents the concept of a C++ namespace declaration |
SgNamespaceDefinitionStatement | This class represents the concept of a namespace definition |
SgNamespaceSymbol | This class represents the concept of a namespace name within the compiler |
SgnAnalysis | |
SgNaryBooleanOp | This class represents the notion of an n-ary boolean operation. This node is intended for use with Python |
SgNaryComparisonOp | This class represents the notion of an n-ary comparison operation. This node is intended for use with Python |
SgNaryOp | This class represents the notion of an n-ary operator. This node is intended for use with Python |
SgNewExp | This class represents the concept of a C++ call to the new operator |
SgnLattice | |
SgNode | This class represents the base class for all IR nodes within Sage III |
SgNonMembershipOp | |
SgNotEqualOp | |
SgNotOp | |
SgNullExpression | |
SgNullifyStatement | |
SgNullStatement | |
SgOmpAlignedClause | |
SgOmpAtomicStatement | |
SgOmpBarrierStatement | |
SgOmpBodyStatement | |
SgOmpClause | |
SgOmpClauseBodyStatement | |
SgOmpCollapseClause | |
SgOmpCopyinClause | |
SgOmpCopyprivateClause | |
SgOmpCriticalStatement | |
SgOmpDefaultClause | |
SgOmpDeviceClause | |
SgOmpDoStatement | |
SgOmpExpressionClause | |
SgOmpFirstprivateClause | |
SgOmpFlushStatement | |
SgOmpForStatement | |
SgOmpIfClause | |
SgOmpLastprivateClause | |
SgOmpLinearClause | |
SgOmpMapClause | |
SgOmpMasterStatement | |
SgOmpNowaitClause | |
SgOmpNumThreadsClause | |
SgOmpOrderedClause | |
SgOmpOrderedStatement | |
SgOmpParallelStatement | |
SgOmpPrivateClause | |
SgOmpReductionClause | |
SgOmpSafelenClause | |
SgOmpScheduleClause | |
SgOmpSectionsStatement | |
SgOmpSectionStatement | |
SgOmpSharedClause | |
SgOmpSimdStatement | |
SgOmpSingleStatement | |
SgOmpTargetDataStatement | |
SgOmpTargetStatement | |
SgOmpTaskStatement | |
SgOmpTaskwaitStatement | |
SgOmpThreadprivateStatement | |
SgOmpUniformClause | |
SgOmpUntiedClause | |
SgOmpVariablesClause | |
SgOmpWorkshareStatement | |
SgOpenclAccessModeModifier | |
SgOpenStatement | |
SgOptions | This class represents an object used to initialize the unparsing |
SgOrOp | |
SgParameterStatement | |
SgPartialFunctionModifierType | |
SgPartialFunctionType | |
SgPassStatement | |
SgPlusAssignOp | |
SgPlusPlusOp | |
SgPntrArrRefExp | |
SgPointerAssignOp | This class represents a Fortran pointer assignment. It is not some weird compound assignment operator like C's += |
SgPointerDerefExp | |
SgPointerMemberType | |
SgPointerType | |
SgPragma | |
SgPragmaDeclaration | This class represents the concept of a C Assembler statement (untested) |
SgPrintStatement | |
SgProcedureHeaderStatement | |
SgProgramHeaderStatement | |
SgProject | This class represents a source project, with a list of SgFile objects and global information about the project (commandline details, AST merge options, etc.) |
SgPseudoDestructorRefExp | |
SgPythonGlobalStmt | This class represents the concept of a 'global' stmt in Python |
SgPythonPrintStmt | |
SgQualifiedName | This class represents qualified names within the IR nodes |
SgQualifiedNameType | |
SgReadStatement | |
SgRealPartOp | |
SgReferenceType | |
SgRefExp | This class represents the "&" operator (applied to any lvalue) |
SgRenamePair | |
SgRenameSymbol | |
SgReturnStmt | This class represents the concept of a C Assembler statement (untested) |
SgRewindStatement | |
SgRshiftAssignOp | |
SgRshiftOp | |
SgScopeOp | This class was part of CC++ support from a long time ago |
SgScopeStatement | This class represents the concept of a scope in C++ (e.g. global scope, fuction scope, etc.) |
SgSequenceStatement | |
SgSetComprehension | |
SgShallowCopy | Supporting class for "Shallow" copies of the AST |
SgSharedVector | |
const_iterator | |
iterator | |
SgShortVal | |
SgSimpleProcessing | |
SgSizeOfOp | This class represents the "sizeof()" operator (applied to any type) |
SgSourceFile | |
SgSpawnStmt | This class is part of the older CC++ concept. It is not a part of C or C++ (this IR node is not used and will be removed in a future release) |
SgSpecialFunctionModifier | |
SgStatement | This class represents the notion of a statement |
SgStatementExpression | This class represents the GNU extension "statement expression" (thus is non-standard C and C++) |
SgStatementFunctionStatement | |
SgStmtDeclarationStatement | This class is intended to be a wrapper around SgStatements, allowing them to exist in scopes that only allow SgDeclarationStatements |
SgStopOrPauseStatement | |
SgStorageModifier | This class represents modifiers specific to storage |
SgStringConversion | This class represents the conversion of an arbitrary expression to a string. This node is intended for use with Python |
SgStringKeyedBidirectionalGraph | |
SgStringVal | |
SgSubscriptExpression | |
SgSubtractOp | |
SgSuperExp | |
SgSupport | This class represents the base class of a numbr of IR nodes that don't otherwise fit into the existing hierarchy of statement, expression, types, and symbols |
SgSwitchStatement | This class represents the concept of a switch |
SgSymbol | This class represents the concept of a name within the compiler |
SgSymbolTable | This class represents the symbol tables used in both SgScopeStatement and the SgFunctionTypeSymbolTable IR node |
SgSynthesizedAttribute | |
SgTemplateArgument | This class represents template argument within the use of a template to build an instantiation |
SgTemplateArgumentList | |
SgTemplateClassDeclaration | |
SgTemplateClassDefinition | |
SgTemplateClassSymbol | |
SgTemplateDeclaration | This class represents the concept of a template declaration |
SgTemplateFunctionDeclaration | |
SgTemplateFunctionDefinition | |
SgTemplateFunctionRefExp | |
SgTemplateFunctionSymbol | |
SgTemplateInstantiationDecl | This class represents the concept of an instantiated class template |
SgTemplateInstantiationDefn | This class represents the concept of a class definition in C++ |
SgTemplateInstantiationDirectiveStatement | This class represents the concept of a C++ template instantiation directive |
SgTemplateInstantiationFunctionDecl | This class represents the concept of an instantiation of function template |
SgTemplateInstantiationMemberFunctionDecl | This class represents the concept of an instantiation of member function template or a member function of an instantiation of a template class |
SgTemplateMemberFunctionDeclaration | |
SgTemplateMemberFunctionRefExp | |
SgTemplateMemberFunctionSymbol | |
SgTemplateParameter | |
SgTemplateParameterList | |
SgTemplateParameterVal | |
SgTemplateSymbol | |
SgTemplateType | |
SgTemplateVariableDeclaration | |
SgTemplateVariableSymbol | |
SgThisExp | This class represents the "this" operator (can be applied to any member data) |
SgThrowOp | This class represents the C++ throw expression (handled as a unary operator) |
SgToken | |
token_element | |
SgTopDownBottomUpProcessing | |
SgTopDownProcessing | |
SgTreeCopy | Supporting class for "Deep" copies of the AST |
SgTreeTraversal | This class is temporary. Do not use |
SgTryStmt | This class represents the concept of try statement within the try-catch support for exception handling in C++ |
SgTupleExp | This class represents a tuple display |
SgType | This class represents the base class for all types |
SgTypeBool | |
SgTypeCAFTeam | |
SgTypeChar | |
SgTypeComplex | This class represents a C99 complex type |
SgTypeCrayPointer | |
SgTypeDefault | This class represents a default type used for some IR nodes (see below) |
SgTypedefDeclaration | This class represents the notion of a typedef declaration |
SgTypedefSeq | This class represents a list of associated typedefs for the SgType IR nodes which reference this list |
SgTypedefSymbol | |
SgTypedefType | |
SgTypeDouble | |
SgTypeEllipse | |
SgTypeFloat | |
SgTypeGlobalVoid | |
SgTypeIdOp | |
SgTypeImaginary | This class represents a C99 complex type |
SgTypeInt | |
SgTypeLabel | |
SgTypeLong | |
SgTypeLongDouble | |
SgTypeLongLong | |
SgTypeModifier | |
SgTypeShort | |
SgTypeSigned128bitInteger | |
SgTypeSignedChar | |
SgTypeSignedInt | |
SgTypeSignedLong | |
SgTypeSignedLongLong | |
SgTypeSignedShort | |
SgTypeString | This class represents a string type used for SgStringVal IR node |
SgTypeTable | |
SgTypeTraitBuiltinOperator | |
SgTypeUnknown | |
SgTypeUnsigned128bitInteger | |
SgTypeUnsignedChar | |
SgTypeUnsignedInt | |
SgTypeUnsignedLong | |
SgTypeUnsignedLongLong | |
SgTypeUnsignedShort | |
SgTypeVoid | |
SgTypeWchar | |
SgUnaryAddOp | |
SgUnaryOp | This class represents the notion of a unary operator. It is derived from a SgExpression because operators are expressions |
SgUndefDirectiveStatement | |
SgUndirectedGraphEdge | |
SgUnknownArrayOrFunctionReference | |
SgUnknownFile | |
SgUnparse_Info | |
SgUnsignedCharVal | |
SgUnsignedIntVal | |
SgUnsignedLongLongIntVal | |
SgUnsignedLongVal | |
SgUnsignedShortVal | |
SgUntypedArrayReferenceExpression | |
SgUntypedArrayType | |
SgUntypedAssignmentStatement | |
SgUntypedAttribute | |
SgUntypedBinaryOperator | |
SgUntypedBlockStatement | |
SgUntypedDeclarationList | |
SgUntypedDeclarationStatement | |
SgUntypedExpression | |
SgUntypedFile | |
SgUntypedFunctionCallOrArrayReferenceExpression | |
SgUntypedFunctionCallStatement | |
SgUntypedFunctionDeclaration | |
SgUntypedFunctionDeclarationList | |
SgUntypedFunctionScope | |
SgUntypedGlobalScope | |
SgUntypedImplicitDeclaration | |
SgUntypedInitializedName | |
SgUntypedInitializedNameList | |
SgUntypedModuleDeclaration | |
SgUntypedModuleScope | |
SgUntypedNamedStatement | |
SgUntypedNode | |
SgUntypedOtherExpression | |
SgUntypedOtherStatement | |
SgUntypedProgramHeaderDeclaration | |
SgUntypedReferenceExpression | |
SgUntypedScope | |
SgUntypedStatement | |
SgUntypedStatementList | |
SgUntypedSubroutineDeclaration | |
SgUntypedType | |
SgUntypedUnaryOperator | |
SgUntypedValueExpression | |
SgUntypedVariableDeclaration | |
SgUPC_AccessModifier | |
SgUpcBarrierStatement | |
SgUpcBlocksizeofExpression | |
SgUpcElemsizeofExpression | |
SgUpcFenceStatement | |
SgUpcForAllStatement | |
SgUpcLocalsizeofExpression | |
SgUpcMythread | |
SgUpcNotifyStatement | |
SgUpcThreads | |
SgUpcWaitStatement | |
SgUserDefinedBinaryOp | |
SgUserDefinedUnaryOp | |
SgUseStatement | |
SgUsingDeclarationStatement | This class represents the concept of a C++ using declaration |
SgUsingDirectiveStatement | This class represents the concept of a C++ using directive |
SgValueExp | This class represents the notion of an value (expression value) |
SgVarArgCopyOp | |
SgVarArgEndOp | |
SgVarArgOp | |
SgVarArgStartOneOperandOp | |
SgVarArgStartOp | |
SgVariableDeclaration | This class represents the concept of a C or C++ variable declaration |
SgVariableDefinition | This class represents the definition (initialization) of a variable |
SgVariableSymbol | This class represents the concept of a variable name within the compiler (a shared container for the declaration of a variable (SgInitializedName)) |
SgVariantExpression | |
SgVariantStatement | |
SgVarRefExp | This class represents the variable refernece in expressions |
SgWaitStatement | |
SgWarningDirectiveStatement | |
SgWcharVal | |
SgWhereStatement | |
SgWhileStmt | This class represents the concept of a do-while statement |
SgWithStatement | |
SgWriteStatement | |
SgXorAssignOp | |
SgYieldExpression | |
SideEffectAnalysis | |
SimpleDirectedGraph | |
SimpleDirectedGraphNode | |
Slicing | |
SlicingCriterion | |
SlicingInfo | |
SortDescending | |
SourceLocationInheritedAttribute | |
StackFrameVector | |
StaticSingleAssignment | Static single assignment analysis |
SteensgaardPtrAnal | |
stmtPatternNode | |
stream_element | |
StringUtility | This class consolidates utility code used within ROSETTA, SAGE, AST Rewrite Mechanism, and AST Processing parts of the ROSE project |
StructCustomizedSizes | Support for cross compilation or extended UPC support |
StructLayoutEntry | |
StructLayoutInfo | |
structureAnn | Pointer structure annotation |
structureTreeAnn | Structure Tree annotation |
Support | |
SystemDependenceGraph | |
SystemPrimitiveTypeLayoutGenerator | Layout generator for the native system (uses sizeof) |
TaintAnalysis | |
TaintLattice | A pointer to a vertex of the static taint lattice |
TerminalNamesType | |
token_element | |
TransformationSupport | This class simplifies the development of queries on the AST resulting in a list of AST nodes.This class holds functions that are generally useful for a broad cross-section of transformations. Functionality specific to any specific transformation should be represented in a similar transformation support class that is a part of the preprocessor source code representing that specific transformation |
TraverseCallGraph | |
TraverseCallGraphBottomUp | |
TraverseCallGraphDataflow | |
TraverseCallGraphTopDown | |
funcRecord | |
TraverseCallGraphUnordered | |
TraverseToRoot | |
typePatternNode | |
UnificationBasedPtr_Ann | |
unionDFAnalysisStatePartitions | |
Unparser | This class represents the Backend C++ Code Generator within ROSE |
UnstructuredPassInterAnalysis | |
UnstructuredPassInterDataflow | |
UnstructuredPassIntraAnalysis | |
UpdateDefUseChainNode | |
Utf8 | |
BadUnicodeException | Class thrown when a Unicode character is encountered |
BadUtf8CodeException | Class thrown when a bad Utf8 sequence is encountered |
ValueAnnotation | |
ValuePropagate | |
ValuePropagateNode | |
varAffineInequality | |
variable | |
VariableRenaming | Class that defines an VariableRenaming of a program |
ChildUses | Attribute that describes the variables used by a given expression |
DefsAndUsesTraversal | This class collects all the defs and uses associated with each node in the traversed CFG |
UniqueNameTraversal | Class to traverse the AST and assign unique names to every varRef |
VarRefSynthAttr | Attribute that describes the variables modified by a given expression |
VariablesProductLattice | |
VariableStateTransfer | |
varID | |
VarsExprsProductLattice | |
VarUniqueName | Class holding a unique name for a variable |
Vertex | |
Vertex2 | |
VirtualFunctionAnalysis | To resolve virtual funcitons correctly we need to answer the question "What are the possible types that an object point to at a call site?" So we basically need to perform Pointer Aliasing Analysis |
Visitor_R | |
visitorTraversal | |
visitorTraversal2 | |
visitorTraversalFunc | |
WorkList | List of things to work on |
WorkListNonUnique | A version of WorkList that does not check for uniqueness by default |
WorkListUnique | A version of WorkList that checks for uniqueness by default |
wrap_data_used_by_AttachPreprocessingInfoTreeTrav_t | |
X86_64_VSPrimitiveTypeLayoutGenerator | Slight modification for Visual Studio – long is 4 bytes, not 8 |
X86_64PrimitiveTypeLayoutGenerator | Layout generator for x86-64 primitive types |
XOMP_accelerator_thread | |
XOMP_mapped_variable | |
YYSTYPE | |