]> Cypherpunks.ru repositories - gostls13.git/blobdiff - src/cmd/compile/internal/pgo/irgraph.go
cmd/compile: support lookup of functions from export data
[gostls13.git] / src / cmd / compile / internal / pgo / irgraph.go
index 4a9de2ef00fcc083f7edae6025ed10b4cd029365..7a7cd20f2b4c9db0e1c7acbd5741a81bf66e1b28 100644 (file)
@@ -49,31 +49,45 @@ import (
        "fmt"
        "internal/profile"
        "os"
+       "sort"
 )
 
-// IRGraph is the key data structure that is built from profile. It is
-// essentially a call graph with nodes pointing to IRs of functions and edges
-// carrying weights and callsite information. The graph is bidirectional that
-// helps in removing nodes efficiently.
+// IRGraph is a call graph with nodes pointing to IRs of functions and edges
+// carrying weights and callsite information.
+//
+// Nodes for indirect calls may have missing IR (IRNode.AST == nil) if the node
+// is not visible from this package (e.g., not in the transitive deps). Keeping
+// these nodes allows determining the hottest edge from a call even if that
+// callee is not available.
+//
+// TODO(prattmic): Consider merging this data structure with Graph. This is
+// effectively a copy of Graph aggregated to line number and pointing to IR.
 type IRGraph struct {
-       // Nodes of the graph
-       IRNodes  map[string]*IRNode
-       OutEdges IREdgeMap
-       InEdges  IREdgeMap
+       // Nodes of the graph. Each node represents a function, keyed by linker
+       // symbol name.
+       IRNodes map[string]*IRNode
 }
 
-// IRNode represents a node in the IRGraph.
+// IRNode represents a node (function) in the IRGraph.
 type IRNode struct {
        // Pointer to the IR of the Function represented by this node.
        AST *ir.Func
-       // Flat weight of the IRNode, obtained from profile.
-       Flat int64
-       // Cumulative weight of the IRNode.
-       Cum int64
+       // Linker symbol name of the Function represented by this node.
+       // Populated only if AST == nil.
+       LinkerSymbolName string
+
+       // Set of out-edges in the callgraph. The map uniquely identifies each
+       // edge based on the callsite and callee, for fast lookup.
+       OutEdges map[NamedCallEdge]*IREdge
 }
 
-// IREdgeMap maps an IRNode to its successors.
-type IREdgeMap map[*IRNode][]*IREdge
+// Name returns the symbol name of this function.
+func (i *IRNode) Name() string {
+       if i.AST != nil {
+               return ir.LinkFuncName(i.AST)
+       }
+       return i.LinkerSymbolName
+}
 
 // IREdge represents a call edge in the IRGraph with source, destination,
 // weight, callsite, and line number information.
@@ -84,19 +98,21 @@ type IREdge struct {
        CallSiteOffset int // Line offset from function start line.
 }
 
-// NodeMapKey represents a hash key to identify unique call-edges in profile
-// and in IR. Used for deduplication of call edges found in profile.
-type NodeMapKey struct {
+// NamedCallEdge identifies a call edge by linker symbol names and call site
+// offset.
+type NamedCallEdge struct {
        CallerName     string
        CalleeName     string
        CallSiteOffset int // Line offset from function start line.
 }
 
-// Weights capture both node weight and edge weight.
-type Weights struct {
-       NFlat   int64
-       NCum    int64
-       EWeight int64
+// NamedEdgeMap contains all unique call edges in the profile and their
+// edge weight.
+type NamedEdgeMap struct {
+       Weight map[NamedCallEdge]int64
+
+       // ByWeight lists all keys in Weight, sorted by edge weight.
+       ByWeight []NamedCallEdge
 }
 
 // CallSiteInfo captures call-site information and its caller/callee.
@@ -109,15 +125,13 @@ type CallSiteInfo struct {
 // Profile contains the processed PGO profile and weighted call graph used for
 // PGO optimizations.
 type Profile struct {
-       // Aggregated NodeWeights and EdgeWeights across the profile. This
-       // helps us determine the percentage threshold for hot/cold
-       // partitioning.
-       TotalNodeWeight int64
-       TotalEdgeWeight int64
+       // Aggregated edge weights across the profile. This helps us determine
+       // the percentage threshold for hot/cold partitioning.
+       TotalWeight int64
 
-       // NodeMap contains all unique call-edges in the profile and their
-       // aggregated weight.
-       NodeMap map[NodeMapKey]*Weights
+       // EdgeMap contains all unique call edges in the profile and their
+       // edge weight.
+       NamedEdgeMap NamedEdgeMap
 
        // WeightedCG represents the IRGraph built from profile, which we will
        // update as part of inlining.
@@ -157,138 +171,159 @@ func New(profileFile string) (*Profile, error) {
        }
 
        g := graph.NewGraph(profile, &graph.Options{
-               CallTree:    false,
                SampleValue: func(v []int64) int64 { return v[valueIndex] },
        })
 
-       p := &Profile{
-               NodeMap: make(map[NodeMapKey]*Weights),
-               WeightedCG: &IRGraph{
-                       IRNodes: make(map[string]*IRNode),
-               },
-       }
-
-       // Build the node map and totals from the profile graph.
-       if err := p.processprofileGraph(g); err != nil {
+       namedEdgeMap, totalWeight, err := createNamedEdgeMap(g)
+       if err != nil {
                return nil, err
        }
 
-       if p.TotalNodeWeight == 0 || p.TotalEdgeWeight == 0 {
+       if totalWeight == 0 {
                return nil, nil // accept but ignore profile with no samples.
        }
 
        // Create package-level call graph with weights from profile and IR.
-       p.initializeIRGraph()
+       wg := createIRGraph(namedEdgeMap)
 
-       return p, nil
+       return &Profile{
+               TotalWeight:  totalWeight,
+               NamedEdgeMap: namedEdgeMap,
+               WeightedCG:   wg,
+       }, nil
 }
 
-// processprofileGraph builds various maps from the profile-graph.
-//
-// It initializes NodeMap and Total{Node,Edge}Weight based on the name and
-// callsite to compute node and edge weights which will be used later on to
-// create edges for WeightedCG.
+// createNamedEdgeMap builds a map of callsite-callee edge weights from the
+// profile-graph.
 //
-// Caller should ignore the profile if p.TotalNodeWeight == 0 || p.TotalEdgeWeight == 0.
-func (p *Profile) processprofileGraph(g *graph.Graph) error {
-       nFlat := make(map[string]int64)
-       nCum := make(map[string]int64)
+// Caller should ignore the profile if totalWeight == 0.
+func createNamedEdgeMap(g *graph.Graph) (edgeMap NamedEdgeMap, totalWeight int64, err error) {
        seenStartLine := false
 
-       // Accummulate weights for the same node.
-       for _, n := range g.Nodes {
-               canonicalName := n.Info.Name
-               nFlat[canonicalName] += n.FlatValue()
-               nCum[canonicalName] += n.CumValue()
-       }
-
        // Process graph and build various node and edge maps which will
        // be consumed by AST walk.
+       weight := make(map[NamedCallEdge]int64)
        for _, n := range g.Nodes {
                seenStartLine = seenStartLine || n.Info.StartLine != 0
 
-               p.TotalNodeWeight += n.FlatValue()
                canonicalName := n.Info.Name
                // Create the key to the nodeMapKey.
-               nodeinfo := NodeMapKey{
+               namedEdge := NamedCallEdge{
                        CallerName:     canonicalName,
                        CallSiteOffset: n.Info.Lineno - n.Info.StartLine,
                }
 
                for _, e := range n.Out {
-                       p.TotalEdgeWeight += e.WeightValue()
-                       nodeinfo.CalleeName = e.Dest.Info.Name
-                       if w, ok := p.NodeMap[nodeinfo]; ok {
-                               w.EWeight += e.WeightValue()
-                       } else {
-                               weights := new(Weights)
-                               weights.NFlat = nFlat[canonicalName]
-                               weights.NCum = nCum[canonicalName]
-                               weights.EWeight = e.WeightValue()
-                               p.NodeMap[nodeinfo] = weights
-                       }
+                       totalWeight += e.WeightValue()
+                       namedEdge.CalleeName = e.Dest.Info.Name
+                       // Create new entry or increment existing entry.
+                       weight[namedEdge] += e.WeightValue()
                }
        }
 
-       if p.TotalNodeWeight == 0 || p.TotalEdgeWeight == 0 {
-               return nil // accept but ignore profile with no samples.
+       if totalWeight == 0 {
+               return NamedEdgeMap{}, 0, nil // accept but ignore profile with no samples.
        }
 
        if !seenStartLine {
                // TODO(prattmic): If Function.start_line is missing we could
                // fall back to using absolute line numbers, which is better
                // than nothing.
-               return fmt.Errorf("profile missing Function.start_line data (Go version of profiled application too old? Go 1.20+ automatically adds this to profiles)")
+               return NamedEdgeMap{}, 0, fmt.Errorf("profile missing Function.start_line data (Go version of profiled application too old? Go 1.20+ automatically adds this to profiles)")
        }
 
-       return nil
+       byWeight := make([]NamedCallEdge, 0, len(weight))
+       for namedEdge := range weight {
+               byWeight = append(byWeight, namedEdge)
+       }
+       sort.Slice(byWeight, func(i, j int) bool {
+               ei, ej := byWeight[i], byWeight[j]
+               if wi, wj := weight[ei], weight[ej]; wi != wj {
+                       return wi > wj // want larger weight first
+               }
+               // same weight, order by name/line number
+               if ei.CallerName != ej.CallerName {
+                       return ei.CallerName < ej.CallerName
+               }
+               if ei.CalleeName != ej.CalleeName {
+                       return ei.CalleeName < ej.CalleeName
+               }
+               return ei.CallSiteOffset < ej.CallSiteOffset
+       })
+
+       edgeMap = NamedEdgeMap{
+               Weight:   weight,
+               ByWeight: byWeight,
+       }
+
+       return edgeMap, totalWeight, nil
 }
 
 // initializeIRGraph builds the IRGraph by visiting all the ir.Func in decl list
 // of a package.
-func (p *Profile) initializeIRGraph() {
+func createIRGraph(namedEdgeMap NamedEdgeMap) *IRGraph {
+       g := &IRGraph{
+               IRNodes: make(map[string]*IRNode),
+       }
+
        // Bottomup walk over the function to create IRGraph.
-       ir.VisitFuncsBottomUp(typecheck.Target.Decls, func(list []*ir.Func, recursive bool) {
-               for _, n := range list {
-                       p.VisitIR(n)
+       ir.VisitFuncsBottomUp(typecheck.Target.Funcs, func(list []*ir.Func, recursive bool) {
+               for _, fn := range list {
+                       visitIR(fn, namedEdgeMap, g)
                }
        })
-}
 
-// VisitIR traverses the body of each ir.Func and use NodeMap to determine if
-// we need to add an edge from ir.Func and any node in the ir.Func body.
-func (p *Profile) VisitIR(fn *ir.Func) {
-       g := p.WeightedCG
+       // Add additional edges for indirect calls. This must be done second so
+       // that IRNodes is fully populated (see the dummy node TODO in
+       // addIndirectEdges).
+       //
+       // TODO(prattmic): visitIR above populates the graph via direct calls
+       // discovered via the IR. addIndirectEdges populates the graph via
+       // calls discovered via the profile. This combination of opposite
+       // approaches is a bit awkward, particularly because direct calls are
+       // discoverable via the profile as well. Unify these into a single
+       // approach.
+       addIndirectEdges(g, namedEdgeMap)
+
+       return g
+}
 
-       if g.IRNodes == nil {
-               g.IRNodes = make(map[string]*IRNode)
-       }
-       if g.OutEdges == nil {
-               g.OutEdges = make(map[*IRNode][]*IREdge)
-       }
-       if g.InEdges == nil {
-               g.InEdges = make(map[*IRNode][]*IREdge)
-       }
+// visitIR traverses the body of each ir.Func adds edges to g from ir.Func to
+// any called function in the body.
+func visitIR(fn *ir.Func, namedEdgeMap NamedEdgeMap, g *IRGraph) {
        name := ir.LinkFuncName(fn)
-       node := new(IRNode)
-       node.AST = fn
-       if g.IRNodes[name] == nil {
+       node, ok := g.IRNodes[name]
+       if !ok {
+               node = &IRNode{
+                       AST: fn,
+               }
                g.IRNodes[name] = node
        }
-       // Create the key for the NodeMapKey.
-       nodeinfo := NodeMapKey{
-               CallerName:     name,
-               CalleeName:     "",
-               CallSiteOffset: 0,
-       }
-       // If the node exists, then update its node weight.
-       if weights, ok := p.NodeMap[nodeinfo]; ok {
-               g.IRNodes[name].Flat = weights.NFlat
-               g.IRNodes[name].Cum = weights.NCum
-       }
 
        // Recursively walk over the body of the function to create IRGraph edges.
-       p.createIRGraphEdge(fn, g.IRNodes[name], name)
+       createIRGraphEdge(fn, node, name, namedEdgeMap, g)
+}
+
+// createIRGraphEdge traverses the nodes in the body of ir.Func and adds edges
+// between the callernode which points to the ir.Func and the nodes in the
+// body.
+func createIRGraphEdge(fn *ir.Func, callernode *IRNode, name string, namedEdgeMap NamedEdgeMap, g *IRGraph) {
+       ir.VisitList(fn.Body, func(n ir.Node) {
+               switch n.Op() {
+               case ir.OCALLFUNC:
+                       call := n.(*ir.CallExpr)
+                       // Find the callee function from the call site and add the edge.
+                       callee := DirectCallee(call.Fun)
+                       if callee != nil {
+                               addIREdge(callernode, name, n, callee, namedEdgeMap, g)
+                       }
+               case ir.OCALLMETH:
+                       call := n.(*ir.CallExpr)
+                       // Find the callee method from the call site and add the edge.
+                       callee := ir.MethodExprName(call.Fun).Func
+                       addIREdge(callernode, name, n, callee, namedEdgeMap, g)
+               }
+       })
 }
 
 // NodeLineOffset returns the line offset of n in fn.
@@ -301,83 +336,155 @@ func NodeLineOffset(n ir.Node, fn *ir.Func) int {
 
 // addIREdge adds an edge between caller and new node that points to `callee`
 // based on the profile-graph and NodeMap.
-func (p *Profile) addIREdge(caller *IRNode, callername string, call ir.Node, callee *ir.Func) {
-       g := p.WeightedCG
-
-       // Create an IRNode for the callee.
-       calleenode := new(IRNode)
-       calleenode.AST = callee
-       calleename := ir.LinkFuncName(callee)
-
-       // Create key for NodeMapKey.
-       nodeinfo := NodeMapKey{
-               CallerName:     callername,
-               CalleeName:     calleename,
-               CallSiteOffset: NodeLineOffset(call, caller.AST),
+func addIREdge(callerNode *IRNode, callerName string, call ir.Node, callee *ir.Func, namedEdgeMap NamedEdgeMap, g *IRGraph) {
+       calleeName := ir.LinkFuncName(callee)
+       calleeNode, ok := g.IRNodes[calleeName]
+       if !ok {
+               calleeNode = &IRNode{
+                       AST: callee,
+               }
+               g.IRNodes[calleeName] = calleeNode
        }
 
-       // Create the callee node with node weight.
-       if g.IRNodes[calleename] == nil {
-               g.IRNodes[calleename] = calleenode
-               nodeinfo2 := NodeMapKey{
-                       CallerName:     calleename,
-                       CalleeName:     "",
-                       CallSiteOffset: 0,
-               }
-               if weights, ok := p.NodeMap[nodeinfo2]; ok {
-                       g.IRNodes[calleename].Flat = weights.NFlat
-                       g.IRNodes[calleename].Cum = weights.NCum
-               }
+       namedEdge := NamedCallEdge{
+               CallerName:     callerName,
+               CalleeName:     calleeName,
+               CallSiteOffset: NodeLineOffset(call, callerNode.AST),
        }
 
-       if weights, ok := p.NodeMap[nodeinfo]; ok {
-               caller.Flat = weights.NFlat
-               caller.Cum = weights.NCum
-
-               // Add edge in the IRGraph from caller to callee.
-               info := &IREdge{Src: caller, Dst: g.IRNodes[calleename], Weight: weights.EWeight, CallSiteOffset: nodeinfo.CallSiteOffset}
-               g.OutEdges[caller] = append(g.OutEdges[caller], info)
-               g.InEdges[g.IRNodes[calleename]] = append(g.InEdges[g.IRNodes[calleename]], info)
-       } else {
-               nodeinfo.CalleeName = ""
-               nodeinfo.CallSiteOffset = 0
-               if weights, ok := p.NodeMap[nodeinfo]; ok {
-                       caller.Flat = weights.NFlat
-                       caller.Cum = weights.NCum
-                       info := &IREdge{Src: caller, Dst: g.IRNodes[calleename], Weight: 0, CallSiteOffset: nodeinfo.CallSiteOffset}
-                       g.OutEdges[caller] = append(g.OutEdges[caller], info)
-                       g.InEdges[g.IRNodes[calleename]] = append(g.InEdges[g.IRNodes[calleename]], info)
-               } else {
-                       info := &IREdge{Src: caller, Dst: g.IRNodes[calleename], Weight: 0, CallSiteOffset: nodeinfo.CallSiteOffset}
-                       g.OutEdges[caller] = append(g.OutEdges[caller], info)
-                       g.InEdges[g.IRNodes[calleename]] = append(g.InEdges[g.IRNodes[calleename]], info)
-               }
+       // Add edge in the IRGraph from caller to callee.
+       edge := &IREdge{
+               Src:            callerNode,
+               Dst:            calleeNode,
+               Weight:         namedEdgeMap.Weight[namedEdge],
+               CallSiteOffset: namedEdge.CallSiteOffset,
        }
+
+       if callerNode.OutEdges == nil {
+               callerNode.OutEdges = make(map[NamedCallEdge]*IREdge)
+       }
+       callerNode.OutEdges[namedEdge] = edge
 }
 
-// createIRGraphEdge traverses the nodes in the body of ir.Func and add edges between callernode which points to the ir.Func and the nodes in the body.
-func (p *Profile) createIRGraphEdge(fn *ir.Func, callernode *IRNode, name string) {
-       var doNode func(ir.Node) bool
-       doNode = func(n ir.Node) bool {
-               switch n.Op() {
-               default:
-                       ir.DoChildren(n, doNode)
-               case ir.OCALLFUNC:
-                       call := n.(*ir.CallExpr)
-                       // Find the callee function from the call site and add the edge.
-                       callee := inlCallee(call.X)
-                       if callee != nil {
-                               p.addIREdge(callernode, name, n, callee)
+// LookupFunc looks up a function or method in export data. It is expected to
+// be overridden by package noder, to break a dependency cycle.
+var LookupFunc = func(fullName string) (*ir.Func, error) {
+       base.Fatalf("pgo.LookupMethodFunc not overridden")
+       panic("unreachable")
+}
+
+// addIndirectEdges adds indirect call edges found in the profile to the graph,
+// to be used for devirtualization.
+//
+// N.B. despite the name, addIndirectEdges will add any edges discovered via
+// the profile. We don't know for sure that they are indirect, but assume they
+// are since direct calls would already be added. (e.g., direct calls that have
+// been deleted from source since the profile was taken would be added here).
+//
+// TODO(prattmic): Devirtualization runs before inlining, so we can't devirtualize
+// calls inside inlined call bodies. If we did add that, we'd need edges from
+// inlined bodies as well.
+func addIndirectEdges(g *IRGraph, namedEdgeMap NamedEdgeMap) {
+       // g.IRNodes is populated with the set of functions in the local
+       // package build by VisitIR. We want to filter for local functions
+       // below, but we also add unknown callees to IRNodes as we go. So make
+       // an initial copy of IRNodes to recall just the local functions.
+       localNodes := make(map[string]*IRNode, len(g.IRNodes))
+       for k, v := range g.IRNodes {
+               localNodes[k] = v
+       }
+
+       // N.B. We must consider edges in a stable order because export data
+       // lookup order (LookupMethodFunc, below) can impact the export data of
+       // this package, which must be stable across different invocations for
+       // reproducibility.
+       //
+       // The weight ordering of ByWeight is irrelevant, it just happens to be
+       // an ordered list of edges that is already available.
+       for _, key := range namedEdgeMap.ByWeight {
+               weight := namedEdgeMap.Weight[key]
+               // All callers in the local package build were added to IRNodes
+               // in VisitIR. If a caller isn't in the local package build we
+               // can skip adding edges, since we won't be devirtualizing in
+               // them anyway. This keeps the graph smaller.
+               callerNode, ok := localNodes[key.CallerName]
+               if !ok {
+                       continue
+               }
+
+               // Already handled this edge?
+               if _, ok := callerNode.OutEdges[key]; ok {
+                       continue
+               }
+
+               calleeNode, ok := g.IRNodes[key.CalleeName]
+               if !ok {
+                       // IR is missing for this callee. VisitIR populates
+                       // IRNodes with all functions discovered via local
+                       // package function declarations and calls. This
+                       // function may still be available from export data of
+                       // a transitive dependency.
+                       //
+                       // TODO(prattmic): Parameterized types/functions are
+                       // not supported.
+                       //
+                       // TODO(prattmic): This eager lookup during graph load
+                       // is simple, but wasteful. We are likely to load many
+                       // functions that we never need. We could delay load
+                       // until we actually need the method in
+                       // devirtualization. Instantiation of generic functions
+                       // will likely need to be done at the devirtualization
+                       // site, if at all.
+                       fn, err := LookupFunc(key.CalleeName)
+                       if err == nil {
+                               if base.Debug.PGODebug >= 3 {
+                                       fmt.Printf("addIndirectEdges: %s found in export data\n", key.CalleeName)
+                               }
+                               calleeNode = &IRNode{AST: fn}
+
+                               // N.B. we could call createIRGraphEdge to add
+                               // direct calls in this newly-imported
+                               // function's body to the graph. Similarly, we
+                               // could add to this function's queue to add
+                               // indirect calls. However, those would be
+                               // useless given the visit order of inlining,
+                               // and the ordering of PGO devirtualization and
+                               // inlining. This function can only be used as
+                               // an inlined body. We will never do PGO
+                               // devirtualization inside an inlined call. Nor
+                               // will we perform inlining inside an inlined
+                               // call.
+                       } else {
+                               // Still not found. Most likely this is because
+                               // the callee isn't in the transitive deps of
+                               // this package.
+                               //
+                               // Record this call anyway. If this is the hottest,
+                               // then we want to skip devirtualization rather than
+                               // devirtualizing to the second most common callee.
+                               if base.Debug.PGODebug >= 3 {
+                                       fmt.Printf("addIndirectEdges: %s not found in export data: %v\n", key.CalleeName, err)
+                               }
+                               calleeNode = &IRNode{LinkerSymbolName: key.CalleeName}
                        }
-               case ir.OCALLMETH:
-                       call := n.(*ir.CallExpr)
-                       // Find the callee method from the call site and add the edge.
-                       callee := ir.MethodExprName(call.X).Func
-                       p.addIREdge(callernode, name, n, callee)
+
+                       // Add dummy node back to IRNodes. We don't need this
+                       // directly, but PrintWeightedCallGraphDOT uses these
+                       // to print nodes.
+                       g.IRNodes[key.CalleeName] = calleeNode
                }
-               return false
+               edge := &IREdge{
+                       Src:            callerNode,
+                       Dst:            calleeNode,
+                       Weight:         weight,
+                       CallSiteOffset: key.CallSiteOffset,
+               }
+
+               if callerNode.OutEdges == nil {
+                       callerNode.OutEdges = make(map[NamedCallEdge]*IREdge)
+               }
+               callerNode.OutEdges[key] = edge
        }
-       doNode(fn)
 }
 
 // WeightInPercentage converts profile weights to a percentage.
@@ -392,7 +499,7 @@ func (p *Profile) PrintWeightedCallGraphDOT(edgeThreshold float64) {
 
        // List of functions in this package.
        funcs := make(map[string]struct{})
-       ir.VisitFuncsBottomUp(typecheck.Target.Decls, func(list []*ir.Func, recursive bool) {
+       ir.VisitFuncsBottomUp(typecheck.Target.Funcs, func(list []*ir.Func, recursive bool) {
                for _, f := range list {
                        name := ir.LinkFuncName(f)
                        funcs[name] = struct{}{}
@@ -400,49 +507,59 @@ func (p *Profile) PrintWeightedCallGraphDOT(edgeThreshold float64) {
        })
 
        // Determine nodes of DOT.
+       //
+       // Note that ir.Func may be nil for functions not visible from this
+       // package.
        nodes := make(map[string]*ir.Func)
        for name := range funcs {
                if n, ok := p.WeightedCG.IRNodes[name]; ok {
-                       for _, e := range p.WeightedCG.OutEdges[n] {
-                               if _, ok := nodes[ir.LinkFuncName(e.Src.AST)]; !ok {
-                                       nodes[ir.LinkFuncName(e.Src.AST)] = e.Src.AST
+                       for _, e := range n.OutEdges {
+                               if _, ok := nodes[e.Src.Name()]; !ok {
+                                       nodes[e.Src.Name()] = e.Src.AST
                                }
-                               if _, ok := nodes[ir.LinkFuncName(e.Dst.AST)]; !ok {
-                                       nodes[ir.LinkFuncName(e.Dst.AST)] = e.Dst.AST
+                               if _, ok := nodes[e.Dst.Name()]; !ok {
+                                       nodes[e.Dst.Name()] = e.Dst.AST
                                }
                        }
-                       if _, ok := nodes[ir.LinkFuncName(n.AST)]; !ok {
-                               nodes[ir.LinkFuncName(n.AST)] = n.AST
+                       if _, ok := nodes[n.Name()]; !ok {
+                               nodes[n.Name()] = n.AST
                        }
                }
        }
 
        // Print nodes.
        for name, ast := range nodes {
-               if n, ok := p.WeightedCG.IRNodes[name]; ok {
-                       nodeweight := WeightInPercentage(n.Flat, p.TotalNodeWeight)
-                       color := "black"
-                       if ast.Inl != nil {
-                               fmt.Printf("\"%v\" [color=%v,label=\"%v,freq=%.2f,inl_cost=%d\"];\n", ir.LinkFuncName(ast), color, ir.LinkFuncName(ast), nodeweight, ast.Inl.Cost)
+               if _, ok := p.WeightedCG.IRNodes[name]; ok {
+                       style := "solid"
+                       if ast == nil {
+                               style = "dashed"
+                       }
+
+                       if ast != nil && ast.Inl != nil {
+                               fmt.Printf("\"%v\" [color=black, style=%s, label=\"%v,inl_cost=%d\"];\n", name, style, name, ast.Inl.Cost)
                        } else {
-                               fmt.Printf("\"%v\" [color=%v, label=\"%v,freq=%.2f\"];\n", ir.LinkFuncName(ast), color, ir.LinkFuncName(ast), nodeweight)
+                               fmt.Printf("\"%v\" [color=black, style=%s, label=\"%v\"];\n", name, style, name)
                        }
                }
        }
        // Print edges.
-       ir.VisitFuncsBottomUp(typecheck.Target.Decls, func(list []*ir.Func, recursive bool) {
+       ir.VisitFuncsBottomUp(typecheck.Target.Funcs, func(list []*ir.Func, recursive bool) {
                for _, f := range list {
                        name := ir.LinkFuncName(f)
                        if n, ok := p.WeightedCG.IRNodes[name]; ok {
-                               for _, e := range p.WeightedCG.OutEdges[n] {
-                                       edgepercent := WeightInPercentage(e.Weight, p.TotalEdgeWeight)
+                               for _, e := range n.OutEdges {
+                                       style := "solid"
+                                       if e.Dst.AST == nil {
+                                               style = "dashed"
+                                       }
+                                       color := "black"
+                                       edgepercent := WeightInPercentage(e.Weight, p.TotalWeight)
                                        if edgepercent > edgeThreshold {
-                                               fmt.Printf("edge [color=red, style=solid];\n")
-                                       } else {
-                                               fmt.Printf("edge [color=black, style=solid];\n")
+                                               color = "red"
                                        }
 
-                                       fmt.Printf("\"%v\" -> \"%v\" [label=\"%.2f\"];\n", ir.LinkFuncName(n.AST), ir.LinkFuncName(e.Dst.AST), edgepercent)
+                                       fmt.Printf("edge [color=%s, style=%s];\n", color, style)
+                                       fmt.Printf("\"%v\" -> \"%v\" [label=\"%.2f\"];\n", n.Name(), e.Dst.Name(), edgepercent)
                                }
                        }
                }
@@ -450,76 +567,11 @@ func (p *Profile) PrintWeightedCallGraphDOT(edgeThreshold float64) {
        fmt.Printf("}\n")
 }
 
-// RedirectEdges deletes and redirects out-edges from node cur based on
-// inlining information via inlinedCallSites.
+// DirectCallee takes a function-typed expression and returns the underlying
+// function that it refers to if statically known. Otherwise, it returns nil.
 //
-// CallSiteInfo.Callee must be nil.
-func (p *Profile) RedirectEdges(cur *IRNode, inlinedCallSites map[CallSiteInfo]struct{}) {
-       g := p.WeightedCG
-
-       i := 0
-       outs := g.OutEdges[cur]
-       for i < len(outs) {
-               outEdge := outs[i]
-               redirected := false
-               _, found := inlinedCallSites[CallSiteInfo{LineOffset: outEdge.CallSiteOffset, Caller: cur.AST}]
-               if !found {
-                       for _, InEdge := range g.InEdges[cur] {
-                               if _, ok := inlinedCallSites[CallSiteInfo{LineOffset: InEdge.CallSiteOffset, Caller: InEdge.Src.AST}]; ok {
-                                       weight := g.calculateWeight(InEdge.Src, cur)
-                                       g.redirectEdge(InEdge.Src, outEdge, weight)
-                                       redirected = true
-                               }
-                       }
-               }
-               if found || redirected {
-                       g.remove(cur, i)
-                       outs = g.OutEdges[cur]
-                       continue
-               }
-               i++
-       }
-}
-
-// redirectEdge redirects a node's out-edge to one of its parent nodes, cloning is
-// required as the node might be inlined in multiple call-sites.
-// TODO: adjust the in-edges of outEdge.Dst if necessary
-func (g *IRGraph) redirectEdge(parent *IRNode, outEdge *IREdge, weight int64) {
-       edge := &IREdge{Src: parent, Dst: outEdge.Dst, Weight: weight * outEdge.Weight, CallSiteOffset: outEdge.CallSiteOffset}
-       g.OutEdges[parent] = append(g.OutEdges[parent], edge)
-}
-
-// remove deletes the cur-node's out-edges at index idx.
-func (g *IRGraph) remove(cur *IRNode, i int) {
-       if len(g.OutEdges[cur]) >= 2 {
-               g.OutEdges[cur][i] = g.OutEdges[cur][len(g.OutEdges[cur])-1]
-               g.OutEdges[cur] = g.OutEdges[cur][:len(g.OutEdges[cur])-1]
-       } else {
-               delete(g.OutEdges, cur)
-       }
-}
-
-// calculateWeight calculates the weight of the new redirected edge.
-func (g *IRGraph) calculateWeight(parent *IRNode, cur *IRNode) int64 {
-       sum := int64(0)
-       pw := int64(0)
-       for _, InEdge := range g.InEdges[cur] {
-               sum += InEdge.Weight
-               if InEdge.Src == parent {
-                       pw = InEdge.Weight
-               }
-       }
-       weight := int64(0)
-       if sum != 0 {
-               weight = pw / sum
-       } else {
-               weight = pw
-       }
-       return weight
-}
-
-// inlCallee is same as the implementation for inl.go with one change. The change is that we do not invoke CanInline on a closure.
-func inlCallee(fn ir.Node) *ir.Func {
+// Equivalent to inline.inlCallee without calling CanInline on closures.
+func DirectCallee(fn ir.Node) *ir.Func {
        fn = ir.StaticValue(fn)
        switch fn.Op() {
        case ir.OMETHEXPR: