changes.
[IRC.git] / Robust / src / Analysis / SSJava / LocationInference.java
index daa435f0e7f80b3df722698c69bc55d4ce44a7cb..60b566869c5bce4511580212ff29075147b40b04 100644 (file)
@@ -13,8 +13,6 @@ import java.util.Map;
 import java.util.Set;
 import java.util.Stack;
 
-import Analysis.SSJava.FlowDownCheck.ComparisonResult;
-import Analysis.SSJava.FlowDownCheck.CompositeLattice;
 import IR.ClassDescriptor;
 import IR.Descriptor;
 import IR.FieldDescriptor;
@@ -25,7 +23,6 @@ import IR.State;
 import IR.SymbolTable;
 import IR.TypeDescriptor;
 import IR.VarDescriptor;
-import IR.Flat.FlatMethod;
 import IR.Tree.ArrayAccessNode;
 import IR.Tree.AssignmentNode;
 import IR.Tree.BlockExpressionNode;
@@ -69,22 +66,18 @@ public class LocationInference {
   // map a method descriptor to a method lattice
   private Map<MethodDescriptor, SSJavaLattice<String>> md2lattice;
 
-  // map a method descriptor to a lattice mapping
-  private Map<MethodDescriptor, Map<VarDescriptor, String>> md2LatticeMapping;
-
-  // map a method descriptor to a lattice mapping
-  private Map<MethodDescriptor, Map<FieldDescriptor, String>> cd2LatticeMapping;
-
-  // map a method descriptor to the set of hierarchy relations that are
-  // contributed from the callee
-  private Map<MethodDescriptor, Set<ParamIndexRelation>> mapMethodDescriptorToCalleeParamRelationSet;
-
   // map a method descriptor to the set of method invocation nodes which are
   // invoked by the method descriptor
   private Map<MethodDescriptor, Set<MethodInvokeNode>> mapMethodDescriptorToMethodInvokeNodeSet;
 
   private Map<MethodInvokeNode, Map<Integer, NTuple<Descriptor>>> mapMethodInvokeNodeToArgIdxMap;
 
+  private Map<MethodDescriptor, MethodLocationInfo> mapMethodDescToMethodLocationInfo;
+
+  private Map<ClassDescriptor, LocationInfo> mapClassToLocationInfo;
+
+  private Map<MethodDescriptor, Set<MethodDescriptor>> mapMethodDescToPossibleMethodDescSet;
+
   boolean debug = true;
 
   public LocationInference(SSJavaAnalysis ssjava, State state) {
@@ -96,15 +89,14 @@ public class LocationInference {
     this.cd2lattice = new HashMap<ClassDescriptor, SSJavaLattice<String>>();
     this.md2lattice = new HashMap<MethodDescriptor, SSJavaLattice<String>>();
     this.methodDescriptorsToVisitStack = new Stack<MethodDescriptor>();
-    this.md2LatticeMapping = new HashMap<MethodDescriptor, Map<VarDescriptor, String>>();
-    this.cd2LatticeMapping = new HashMap<MethodDescriptor, Map<FieldDescriptor, String>>();
-    this.mapMethodDescriptorToCalleeParamRelationSet =
-        new HashMap<MethodDescriptor, Set<ParamIndexRelation>>();
     this.mapMethodDescriptorToMethodInvokeNodeSet =
         new HashMap<MethodDescriptor, Set<MethodInvokeNode>>();
     this.mapMethodInvokeNodeToArgIdxMap =
         new HashMap<MethodInvokeNode, Map<Integer, NTuple<Descriptor>>>();
-
+    this.mapMethodDescToMethodLocationInfo = new HashMap<MethodDescriptor, MethodLocationInfo>();
+    this.mapMethodDescToPossibleMethodDescSet =
+        new HashMap<MethodDescriptor, Set<MethodDescriptor>>();
+    this.mapClassToLocationInfo = new HashMap<ClassDescriptor, LocationInfo>();
   }
 
   public void setupToAnalyze() {
@@ -156,6 +148,30 @@ public class LocationInference {
 
     debug_writeLatticeDotFile();
 
+    // 3) check properties
+    checkLattices();
+
+  }
+
+  private void checkLattices() {
+
+    LinkedList<MethodDescriptor> descriptorListToAnalyze = ssjava.getSortedDescriptors();
+
+    // current descriptors to visit in fixed-point interprocedural analysis,
+    // prioritized by
+    // dependency in the call graph
+    methodDescriptorsToVisitStack.clear();
+
+    descriptorListToAnalyze.removeFirst();
+
+    Set<MethodDescriptor> methodDescriptorToVistSet = new HashSet<MethodDescriptor>();
+    methodDescriptorToVistSet.addAll(descriptorListToAnalyze);
+
+    while (!descriptorListToAnalyze.isEmpty()) {
+      MethodDescriptor md = descriptorListToAnalyze.removeFirst();
+      checkLatticesOfVirtualMethods(md);
+    }
+
   }
 
   private void debug_writeLatticeDotFile() {
@@ -190,7 +206,6 @@ public class LocationInference {
 
     // do fixed-point analysis
 
-    // perform method READ/OVERWRITE analysis
     LinkedList<MethodDescriptor> descriptorListToAnalyze = ssjava.getSortedDescriptors();
 
     // current descriptors to visit in fixed-point interprocedural analysis,
@@ -214,7 +229,7 @@ public class LocationInference {
       MethodDescriptor md = methodDescriptorsToVisitStack.pop();
 
       SSJavaLattice<String> methodLattice =
-          new SSJavaLattice<String>(SSJavaLattice.TOP, SSJavaLattice.BOTTOM);
+          new SSJavaLattice<String>(SSJavaAnalysis.TOP, SSJavaAnalysis.BOTTOM);
 
       System.out.println();
       System.out.println("SSJAVA: Inferencing the lattice from " + md);
@@ -224,7 +239,8 @@ public class LocationInference {
       SSJavaLattice<String> prevMethodLattice = getMethodLattice(md);
 
       if (!methodLattice.equals(prevMethodLattice)) {
-        md2lattice.put(md, methodLattice);
+
+        setMethodLattice(md, methodLattice);
 
         // results for callee changed, so enqueue dependents caller for
         // further analysis
@@ -243,19 +259,80 @@ public class LocationInference {
 
   }
 
+  private void checkLatticesOfVirtualMethods(MethodDescriptor md) {
+
+    if (!md.isStatic()) {
+      Set<MethodDescriptor> setPossibleCallees = new HashSet<MethodDescriptor>();
+      setPossibleCallees.addAll(ssjava.getCallGraph().getMethods(md));
+
+      for (Iterator iterator = setPossibleCallees.iterator(); iterator.hasNext();) {
+        MethodDescriptor mdCallee = (MethodDescriptor) iterator.next();
+        if (!md.equals(mdCallee)) {
+          checkConsistency(md, mdCallee);
+        }
+      }
+
+    }
+
+  }
+
+  private void checkConsistency(MethodDescriptor md1, MethodDescriptor md2) {
+
+    // check that two lattice have the same relations between parameters(+PC
+    // LOC, RETURN LOC)
+
+    MethodLocationInfo methodInfo1 = getMethodLocationInfo(md1);
+
+    SSJavaLattice<String> lattice1 = getMethodLattice(md1);
+    SSJavaLattice<String> lattice2 = getMethodLattice(md2);
+
+    Set<String> paramLocNameSet1 = methodInfo1.getParameterLocNameSet();
+
+    for (Iterator iterator = paramLocNameSet1.iterator(); iterator.hasNext();) {
+      String locName1 = (String) iterator.next();
+      for (Iterator iterator2 = paramLocNameSet1.iterator(); iterator2.hasNext();) {
+        String locName2 = (String) iterator2.next();
+
+        // System.out.println("COMPARE " + locName1 + " - " + locName2 + " "
+        // + lattice1.isGreaterThan(locName1, locName2) + "-"
+        // + lattice2.isGreaterThan(locName1, locName2));
+
+        if (!locName1.equals(locName2)) {
+
+          boolean r1 = lattice1.isGreaterThan(locName1, locName2);
+          boolean r2 = lattice2.isGreaterThan(locName1, locName2);
+
+          if (r1 != r2) {
+            throw new Error("The method " + md1 + " is not consistent with the method " + md2
+                + ".:: They have a different ordering relation between parameters " + locName1
+                + " and " + locName2 + ".");
+          }
+        }
+
+      }
+    }
+
+  }
+
   private String getSymbol(int idx, FlowNode node) {
     Descriptor desc = node.getDescTuple().get(idx);
     return desc.getSymbol();
   }
 
+  private Descriptor getDescriptor(int idx, FlowNode node) {
+    Descriptor desc = node.getDescTuple().get(idx);
+    return desc;
+  }
+
   private void analyzeMethodLattice(MethodDescriptor md, SSJavaLattice<String> methodLattice) {
 
+    MethodLocationInfo methodInfo = getMethodLocationInfo(md);
+
     // first take a look at method invocation nodes to newly added relations
     // from the callee
     analyzeLatticeMethodInvocationNode(md);
 
     // visit each node of method flow graph
-
     FlowGraph fg = getFlowGraph(md);
     Set<FlowNode> nodeSet = fg.getNodeSet();
 
@@ -264,16 +341,65 @@ public class LocationInference {
     for (Iterator iterator = nodeSet.iterator(); iterator.hasNext();) {
       FlowNode srcNode = (FlowNode) iterator.next();
 
-      // first, take a look at directly connected nodes
       Set<FlowEdge> outEdgeSet = srcNode.getOutEdgeSet();
       for (Iterator iterator2 = outEdgeSet.iterator(); iterator2.hasNext();) {
         FlowEdge outEdge = (FlowEdge) iterator2.next();
         FlowNode dstNode = outEdge.getDst();
 
-        addRelationToLattice(md, methodLattice, srcNode, dstNode);
+        NTuple<Descriptor> srcNodeTuple = srcNode.getDescTuple();
+        NTuple<Descriptor> dstNodeTuple = dstNode.getDescTuple();
+
+        if (outEdge.getInitTuple().equals(srcNodeTuple)
+            && outEdge.getEndTuple().equals(dstNodeTuple)) {
+
+          if ((srcNodeTuple.size() > 1 && dstNodeTuple.size() > 1)
+              && srcNodeTuple.get(0).equals(dstNodeTuple.get(0))) {
+
+            // value flows between fields
+            VarDescriptor varDesc = (VarDescriptor) srcNodeTuple.get(0);
+            ClassDescriptor varClassDesc = varDesc.getType().getClassDesc();
+            extractRelationFromFieldFlows(varClassDesc, srcNode, dstNode, 1);
+
+          } else {
+            // for the method lattice, we need to look at the first element of
+            // NTuple<Descriptor>
+            if (srcNodeTuple.size() == 1 || dstNodeTuple.size() == 1) {
+              // in this case, take a look at connected nodes at the local level
+              addRelationToLattice(md, methodLattice, srcNode, dstNode);
+            }
+          }
+
+        }
+      }
+    }
+
+    // grab the this location if the method use the 'this' reference
+    String thisLocSymbol = md.getThis().getSymbol();
+    if (methodLattice.getKeySet().contains(thisLocSymbol)) {
+      methodInfo.setThisLocName(thisLocSymbol);
+    }
+
+    // calculate a return location
+    if (!md.getReturnType().isVoid()) {
+      Set<FlowNode> returnNodeSet = fg.getReturnNodeSet();
+      Set<String> returnVarSymbolSet = new HashSet<String>();
 
+      for (Iterator iterator = returnNodeSet.iterator(); iterator.hasNext();) {
+        FlowNode rtrNode = (FlowNode) iterator.next();
+        String localSymbol = rtrNode.getDescTuple().get(0).getSymbol();
+        returnVarSymbolSet.add(localSymbol);
       }
 
+      String returnGLB = methodLattice.getGLB(returnVarSymbolSet);
+      if (returnGLB.equals(SSJavaAnalysis.BOTTOM)) {
+        // need to insert a new location in-between the bottom and all locations
+        // that is directly connected to the bottom
+        String returnNewLocationSymbol = "Loc" + (SSJavaLattice.seed++);
+        methodLattice.insertNewLocationAtOneLevelHigher(returnGLB, returnNewLocationSymbol);
+        methodInfo.setReturnLocName(returnNewLocationSymbol);
+      } else {
+        methodInfo.setReturnLocName(returnGLB);
+      }
     }
 
   }
@@ -327,9 +453,10 @@ public class LocationInference {
 
         String paramSymbol1 = getSymbol(0, paramFlowNode1);
         String paramSymbol2 = getSymbol(0, paramFlowNode2);
-        // if two parameters have relation, we need to propagate this relation
+        // if two parameters have relation, we need to propagate this relation
         // to the caller
-        if (calleeLattice.isComparable(paramSymbol1, paramSymbol2)) {
+        if (!(paramSymbol1.equals(paramSymbol2))
+            && calleeLattice.isComparable(paramSymbol1, paramSymbol2)) {
           int higherLocIdxCallee;
           int lowerLocIdxCallee;
           if (calleeLattice.isGreaterThan(paramSymbol1, paramSymbol2)) {
@@ -353,55 +480,397 @@ public class LocationInference {
 
   }
 
+  private LocationInfo getLocationInfo(Descriptor d) {
+    if (d instanceof MethodDescriptor) {
+      return getMethodLocationInfo((MethodDescriptor) d);
+    } else {
+      return getFieldLocationInfo((ClassDescriptor) d);
+    }
+  }
+
+  private MethodLocationInfo getMethodLocationInfo(MethodDescriptor md) {
+
+    if (!mapMethodDescToMethodLocationInfo.containsKey(md)) {
+      mapMethodDescToMethodLocationInfo.put(md, new MethodLocationInfo(md));
+    }
+
+    return mapMethodDescToMethodLocationInfo.get(md);
+
+  }
+
+  private LocationInfo getFieldLocationInfo(ClassDescriptor cd) {
+
+    if (!mapClassToLocationInfo.containsKey(cd)) {
+      mapClassToLocationInfo.put(cd, new LocationInfo(cd));
+    }
+
+    return mapClassToLocationInfo.get(cd);
+
+  }
+
   private void addRelationToLattice(MethodDescriptor md, SSJavaLattice<String> methodLattice,
       FlowNode srcNode, FlowNode dstNode) {
-    if ((srcNode.getDescTuple().size() > 1 && dstNode.getDescTuple().size() > 1)
-        && srcNode.getDescTuple().get(0).equals(dstNode.getDescTuple().get(0))) {
-      // value flow between fields: we don't need to add a binary relation
-      // for this case
 
-      VarDescriptor varDesc = (VarDescriptor) srcNode.getDescTuple().get(0);
-      ClassDescriptor varClassDesc = varDesc.getType().getClassDesc();
+    System.out.println("### addRelationToLattice src=" + srcNode + " dst=" + dstNode);
+
+    // add a new binary relation of dstNode < srcNode
+    FlowGraph flowGraph = getFlowGraph(md);
+    MethodLocationInfo methodInfo = getMethodLocationInfo(md);
+
+    String srcOriginSymbol = getSymbol(0, srcNode);
+    String dstOriginSymbol = getSymbol(0, dstNode);
+
+    Descriptor srcDesc = getDescriptor(0, srcNode);
+    Descriptor dstDesc = getDescriptor(0, dstNode);
+
+    String srcSymbol = methodInfo.getLocName(srcOriginSymbol);
+    String dstSymbol = methodInfo.getLocName(dstOriginSymbol);
 
-      extractRelationFromFieldFlows(varClassDesc, srcNode, dstNode, 1);
-      return;
+    if (srcNode.isParameter()) {
+      int paramIdx = flowGraph.getParamIdx(srcNode.getDescTuple());
+      methodInfo.addParameter(srcSymbol, srcDesc, paramIdx);
+    } else {
+      methodInfo.addMappingOfLocNameToDescriptor(srcSymbol, srcDesc);
     }
 
-    // add a new binary relation of dstNode < srcNode
+    if (dstNode.isParameter()) {
+      int paramIdx = flowGraph.getParamIdx(dstNode.getDescTuple());
+      methodInfo.addParameter(dstSymbol, dstDesc, paramIdx);
+    } else {
+      methodInfo.addMappingOfLocNameToDescriptor(dstSymbol, dstDesc);
+    }
+
+    // consider a composite location case
+
+    boolean isSrcLocalVar = false;
+    boolean isDstLocalVar = false;
+    if (srcNode.getDescTuple().size() == 1) {
+      isSrcLocalVar = true;
+    }
+
+    if (dstNode.getDescTuple().size() == 1) {
+      isDstLocalVar = true;
+    }
+
+    boolean isAssignedCompositeLocation = false;
+    if (isSrcLocalVar && isDstLocalVar) {
+      // both src and dst are local var
+
+      // CompositeLocation inferSrc=methodInfo.getInferLocation(srcNode);
+      // CompositeLocation inferDst=methodInfo.getInferLocation(dstNode);
+      // if( (inferSrc!=null && inferSrc.getSize()>1) || (inferDst!=null &&
+      // inferDst.getSize()>1)){
+      // isAssignedCompositeLocation = true;
+      // }
+
+      // TODO: need to fix
+      isAssignedCompositeLocation =
+          calculateCompositeLocationForLocalVar(flowGraph, methodLattice, methodInfo, srcNode);
+      calculateCompositeLocationForLocalVar(flowGraph, methodLattice, methodInfo, dstNode);
+
+    } else if (isSrcLocalVar) {
+      // src is local var
+      isAssignedCompositeLocation =
+          calculateCompositeLocationForLocalVar(flowGraph, methodLattice, methodInfo, srcNode);
+    } else if (isDstLocalVar) {
+      // dst is local var
+      isAssignedCompositeLocation =
+          calculateCompositeLocationForLocalVar(flowGraph, methodLattice, methodInfo, dstNode);
+    }
 
-    String srcSymbol = getSymbol(0, srcNode);
-    String dstSymbol = getSymbol(0, dstNode);
+    if (!isAssignedCompositeLocation) {
+      if (!methodLattice.isGreaterThan(srcSymbol, dstSymbol)) {
+        // if the lattice does not have this relation, add it
+        methodLattice.addRelationHigherToLower(srcSymbol, dstSymbol);
+      }
+    }
 
-    methodLattice.addRelationHigherToLower(srcSymbol, dstSymbol);
+    // Set<String> cycleElementSet =
+    // methodLattice.getPossibleCycleElements(srcSymbol, dstSymbol);
+    //
+    // System.out.println("### POSSIBLE CYCLE ELEMENT SET=" + cycleElementSet);
+    // boolean hasNonPrimitiveElement = false;
+    // for (Iterator iterator = cycleElementSet.iterator(); iterator.hasNext();)
+    // {
+    // String cycleElementSymbol = (String) iterator.next();
+    // Set<Descriptor> flowNodeSet =
+    // methodInfo.getFlowNodeSet(cycleElementSymbol);
+    // for (Iterator iterator2 = flowNodeSet.iterator(); iterator2.hasNext();) {
+    // Descriptor desc = (Descriptor) iterator2.next();
+    // if (!isPrimitiveTypeDescriptor(desc)) {
+    // hasNonPrimitiveElement = true;
+    // }
+    // System.out
+    // .println("flowNode=" + desc + " is primitive?=" +
+    // isPrimitiveTypeDescriptor(desc));
+    // }
+    // }
+    //
+    // if (hasNonPrimitiveElement) {
+    // // if there is non-primitive element in the cycle, no way to merge cyclic
+    // // elements into the shared location
+    // System.out.println("Failed to merge cyclic value flows into a shared location.");
+    //
+    // // try to assign more fine-grind composite location to the source or the
+    // // destination
+    // System.out.println("SRC=" + srcSymbol + "    DST=" + dstSymbol);
+    // System.out.println("### SRCNODE=" + srcNode + " DSTNODE=" + dstNode);
+    //
+    // FlowNode targetNode;
+    // if (isPrimitiveLocalVariable(srcNode)) {
+    // targetNode = srcNode;
+    // } else {
+    // targetNode = dstNode;
+    // }
+    //
+    // calculateMoreFineGrainedLocation(md, methodLattice, targetNode);
+    //
+    // return;
+    // }
+    //
+    // if (cycleElementSet.size() > 0) {
+    // String newSharedLoc = "SharedLoc" + (SSJavaLattice.seed++);
+    // methodLattice.mergeIntoSharedLocation(cycleElementSet, newSharedLoc);
+    //
+    // for (Iterator iterator = cycleElementSet.iterator(); iterator.hasNext();)
+    // {
+    // String locName = (String) iterator.next();
+    // methodInfo.mapDescSymbolToLocName(locName, newSharedLoc);
+    // }
+    //
+    // } else if (!methodLattice.isGreaterThan(srcSymbol, dstSymbol)) {
+    // // if the lattice does not have this relation, add it
+    // methodLattice.addRelationHigherToLower(srcSymbol, dstSymbol);
+    // }
+    //
+    // System.out.println("methodLattice=" + methodLattice.getKeySet());
 
   }
 
-  private SSJavaLattice<String> getMethodLattice(MethodDescriptor md) {
+  private void addPrefixMapping(Map<NTuple<Location>, Set<NTuple<Location>>> map,
+      NTuple<Location> prefix, NTuple<Location> element) {
+
+    if (!map.containsKey(prefix)) {
+      map.put(prefix, new HashSet<NTuple<Location>>());
+    }
+    map.get(prefix).add(element);
+
+  }
+
+  private NTuple<Location> getLocationTuple(MethodLocationInfo methodInfo, FlowGraph flowGraph,
+      FlowNode flowNode) {
+
+    NTuple<Location> locTuple;
+    CompositeLocation inferLoc = methodInfo.getInferLocation(flowNode);
+    if (inferLoc != null) {
+      // the flow node has already been assigned to the location
+      locTuple = new NTuple<Location>();
+      NTuple<Location> inferLocTuple = inferLoc.getTuple();
+      for (int i = 0; i < inferLocTuple.size(); i++) {
+        locTuple.add(inferLocTuple.get(i));
+      }
+    } else {
+      locTuple = flowGraph.getLocationTuple(flowNode);
+    }
+
+    return locTuple;
+  }
+
+  private boolean calculateCompositeLocationForLocalVar(FlowGraph flowGraph,
+      SSJavaLattice<String> methodLattice, MethodLocationInfo methodInfo, FlowNode flowNode) {
+
+    Set<FlowNode> inNodeSet = flowGraph.getIncomingFlowNodeSet(flowNode);
+    Set<FlowNode> reachableNodeSet = flowGraph.getReachableFlowNodeSet(flowNode);
+
+    Map<NTuple<Location>, Set<NTuple<Location>>> mapPrefixToIncomingLocTupleSet =
+        new HashMap<NTuple<Location>, Set<NTuple<Location>>>();
+
+    List<NTuple<Location>> prefixList = new ArrayList<NTuple<Location>>();
+
+    for (Iterator iterator = inNodeSet.iterator(); iterator.hasNext();) {
+      FlowNode inNode = (FlowNode) iterator.next();
+      NTuple<Location> inTuple = getLocationTuple(methodInfo, flowGraph, inNode);
+
+      if (inTuple.size() > 1) {
+        for (int i = 1; i < inTuple.size(); i++) {
+          NTuple<Location> prefix = inTuple.subList(0, i);
+          if (!prefixList.contains(prefix)) {
+            prefixList.add(prefix);
+          }
+          addPrefixMapping(mapPrefixToIncomingLocTupleSet, prefix, inTuple);
+        }
+      }
+    }
+
+    Collections.sort(prefixList, new Comparator<NTuple<Location>>() {
+      public int compare(NTuple<Location> arg0, NTuple<Location> arg1) {
+        int s0 = arg0.size();
+        int s1 = arg1.size();
+        if (s0 > s1) {
+          return -1;
+        } else if (s0 == s1) {
+          return 0;
+        } else {
+          return 1;
+        }
+      }
+    });
+
+    // find out reachable nodes that have the longest common prefix
+    for (int i = 0; i < prefixList.size(); i++) {
+      NTuple<Location> curPrefix = prefixList.get(i);
+      Set<NTuple<Location>> reachableCommonPrefixSet = new HashSet<NTuple<Location>>();
+
+      for (Iterator iterator2 = reachableNodeSet.iterator(); iterator2.hasNext();) {
+        FlowNode reachableNode = (FlowNode) iterator2.next();
+        NTuple<Location> reachLocTuple = flowGraph.getLocationTuple(reachableNode);
+        if (reachLocTuple.startsWith(curPrefix)) {
+          reachableCommonPrefixSet.add(reachLocTuple);
+        }
+      }
+
+      if (!reachableCommonPrefixSet.isEmpty()) {
+        Set<NTuple<Location>> incomingCommonPrefixSet =
+            mapPrefixToIncomingLocTupleSet.get(curPrefix);
+
+        int idx = curPrefix.size();
+        NTuple<Location> element = incomingCommonPrefixSet.iterator().next();
+        Descriptor desc = element.get(idx).getDescriptor();
+
+        SSJavaLattice<String> lattice = getLattice(desc);
+        LocationInfo locInfo = getLocationInfo(desc);
+
+        CompositeLocation inferNode = methodInfo.getInferLocation(flowNode);
+        String nodeSymbol;
+        if (inferNode != null) {
+
+        } else {
+          String newLocSymbol = "Loc" + (SSJavaLattice.seed++);
+          inferNode = new CompositeLocation();
+          for (int locIdx = 0; locIdx < curPrefix.size(); locIdx++) {
+            inferNode.addLocation(curPrefix.get(locIdx));
+          }
+          inferNode.addLocation(new Location(desc, newLocSymbol));
+          methodInfo.mapFlowNodeToInferLocation(flowNode, inferNode);
+          if (flowNode.getDescTuple().size() == 1) {
+            // local variable case
+            modifyLocalLatticeAccrodingToNewlyAddedCompositeLocation(methodLattice, methodInfo,
+                inferNode, flowNode);
+          }
+        }
+
+        nodeSymbol = inferNode.get(inferNode.getSize() - 1).getLocIdentifier();
+
+        for (Iterator iterator = incomingCommonPrefixSet.iterator(); iterator.hasNext();) {
+          NTuple<Location> tuple = (NTuple<Location>) iterator.next();
+          Location loc = tuple.get(idx);
+          String higher = locInfo.getLocName(loc.getLocIdentifier());
+          lattice.addRelationHigherToLower(higher, nodeSymbol);
+        }
+
+        for (Iterator iterator = reachableCommonPrefixSet.iterator(); iterator.hasNext();) {
+          NTuple<Location> tuple = (NTuple<Location>) iterator.next();
+          Location loc = tuple.get(idx);
+          String lower = locInfo.getLocName(loc.getLocIdentifier());
+          lattice.addRelationHigherToLower(nodeSymbol, lower);
+        }
+
+        return true;
+      }
+
+    }
+
+    return false;
+
+  }
+
+  private void modifyLocalLatticeAccrodingToNewlyAddedCompositeLocation(
+      SSJavaLattice<String> methodLattice, MethodLocationInfo methodInfo,
+      CompositeLocation inferNode, FlowNode flowNode) {
+
+    Location localLocation = inferNode.get(0);
+    String newLocName = methodInfo.getLocName(localLocation.getLocIdentifier());
+    String oldLocName = methodInfo.getLocName(flowNode.getDescTuple().get(0).getSymbol());
+
+    methodInfo.mapDescSymbolToLocName(oldLocName, newLocName);
+    methodLattice.substituteLocation(oldLocName, newLocName);
+
+  }
+
+  public boolean isPrimitiveLocalVariable(FlowNode node) {
+    VarDescriptor varDesc = (VarDescriptor) node.getDescTuple().get(0);
+    return varDesc.getType().isPrimitive();
+  }
+
+  private SSJavaLattice<String> getLattice(Descriptor d) {
+    if (d instanceof MethodDescriptor) {
+      return getMethodLattice((MethodDescriptor) d);
+    } else {
+      return getFieldLattice((ClassDescriptor) d);
+    }
+  }
 
+  private SSJavaLattice<String> getMethodLattice(MethodDescriptor md) {
     if (!md2lattice.containsKey(md)) {
-      md2lattice.put(md, new SSJavaLattice<String>(SSJavaLattice.TOP, SSJavaLattice.BOTTOM));
+      md2lattice.put(md, new SSJavaLattice<String>(SSJavaAnalysis.TOP, SSJavaAnalysis.BOTTOM));
     }
     return md2lattice.get(md);
   }
 
+  private void setMethodLattice(MethodDescriptor md, SSJavaLattice<String> lattice) {
+    md2lattice.put(md, lattice);
+  }
+
   private void extractRelationFromFieldFlows(ClassDescriptor cd, FlowNode srcNode,
       FlowNode dstNode, int idx) {
 
-    if (srcNode.getDescTuple().get(idx).equals(dstNode.getDescTuple().get(idx))) {
+    if (srcNode.getDescTuple().get(idx).equals(dstNode.getDescTuple().get(idx))
+        && srcNode.getDescTuple().size() > (idx + 1) && dstNode.getDescTuple().size() > (idx + 1)) {
       // value flow between fields: we don't need to add a binary relation
       // for this case
-      VarDescriptor varDesc = (VarDescriptor) srcNode.getDescTuple().get(idx);
-      ClassDescriptor varClassDesc = varDesc.getType().getClassDesc();
-      extractRelationFromFieldFlows(varClassDesc, srcNode, dstNode, idx + 1);
+
+      Descriptor desc = srcNode.getDescTuple().get(idx);
+      ClassDescriptor classDesc;
+
+      if (idx == 0) {
+        classDesc = ((VarDescriptor) desc).getType().getClassDesc();
+      } else {
+        classDesc = ((FieldDescriptor) desc).getType().getClassDesc();
+      }
+
+      extractRelationFromFieldFlows(classDesc, srcNode, dstNode, idx + 1);
+
     } else {
 
       Descriptor srcFieldDesc = srcNode.getDescTuple().get(idx);
       Descriptor dstFieldDesc = dstNode.getDescTuple().get(idx);
 
       // add a new binary relation of dstNode < srcNode
-
       SSJavaLattice<String> fieldLattice = getFieldLattice(cd);
-      fieldLattice.addRelationHigherToLower(srcFieldDesc.getSymbol(), dstFieldDesc.getSymbol());
+
+      String srcOriginalSymbol = srcFieldDesc.getSymbol();
+      String dstOriginalSymbol = dstFieldDesc.getSymbol();
+
+      LocationInfo fieldInfo = getFieldLocationInfo(cd);
+
+      String srcSymbol = fieldInfo.getLocName(srcOriginalSymbol);
+      String dstSymbol = fieldInfo.getLocName(dstOriginalSymbol);
+
+      Set<String> cycleElementSet = fieldLattice.getPossibleCycleElements(srcSymbol, dstSymbol);
+
+      if (cycleElementSet.size() > 0) {
+        String newSharedLoc = "SharedLoc" + (SSJavaLattice.seed++);
+        fieldLattice.mergeIntoSharedLocation(cycleElementSet, newSharedLoc);
+
+        for (Iterator iterator = cycleElementSet.iterator(); iterator.hasNext();) {
+          String locName = (String) iterator.next();
+          fieldInfo.mapDescSymbolToLocName(locName, newSharedLoc);
+        }
+
+      } else if (!fieldLattice.isGreaterThan(srcSymbol, dstSymbol)) {
+        // if the lattice does not have this relation, add it
+        fieldLattice.addRelationHigherToLower(srcSymbol, dstSymbol);
+      }
 
     }
 
@@ -409,7 +878,7 @@ public class LocationInference {
 
   public SSJavaLattice<String> getFieldLattice(ClassDescriptor cd) {
     if (!cd2lattice.containsKey(cd)) {
-      cd2lattice.put(cd, new SSJavaLattice<String>(SSJavaLattice.TOP, SSJavaLattice.BOTTOM));
+      cd2lattice.put(cd, new SSJavaLattice<String>(SSJavaAnalysis.TOP, SSJavaAnalysis.BOTTOM));
     }
     return cd2lattice.get(cd);
   }
@@ -426,11 +895,20 @@ public class LocationInference {
         MethodDescriptor md = toAnalyzeMethodNext();
         if (ssjava.needTobeAnnotated(md)) {
           if (state.SSJAVADEBUG) {
+            System.out.println();
             System.out.println("SSJAVA: Constructing a flow graph: " + md);
           }
 
-          // creates a mapping from a parameter descriptor to its index
+          // creates a mapping from a method descriptor to virtual methods
+          Set<MethodDescriptor> setPossibleCallees = new HashSet<MethodDescriptor>();
+          if (md.isStatic()) {
+            setPossibleCallees.add(md);
+          } else {
+            setPossibleCallees.addAll(ssjava.getCallGraph().getMethods(md));
+          }
+          mapMethodDescToPossibleMethodDescSet.put(md, setPossibleCallees);
 
+          // creates a mapping from a parameter descriptor to its index
           Map<Descriptor, Integer> mapParamDescToIdx = new HashMap<Descriptor, Integer>();
           int offset = md.isStatic() ? 0 : 1;
           for (int i = 0; i < md.numParameters(); i++) {
@@ -487,7 +965,7 @@ public class LocationInference {
       break;
 
     case Kind.ReturnNode:
-      analyzeReturnNode(md, nametable, (ReturnNode) bsn);
+      analyzeFlowReturnNode(md, nametable, (ReturnNode) bsn, implicitFlowTupleSet);
       break;
 
     case Kind.SubBlockNode:
@@ -515,8 +993,25 @@ public class LocationInference {
     analyzeFlowBlockNode(md, nametable, sbn.getBlockNode(), implicitFlowTupleSet);
   }
 
-  private void analyzeReturnNode(MethodDescriptor md, SymbolTable nametable, ReturnNode bsn) {
-    // TODO Auto-generated method stub
+  private void analyzeFlowReturnNode(MethodDescriptor md, SymbolTable nametable, ReturnNode rn,
+      NodeTupleSet implicitFlowTupleSet) {
+
+    ExpressionNode returnExp = rn.getReturnExpression();
+
+    NodeTupleSet nodeSet = new NodeTupleSet();
+    analyzeFlowExpressionNode(md, nametable, returnExp, nodeSet, false);
+
+    FlowGraph fg = getFlowGraph(md);
+
+    // annotate the elements of the node set as the return location
+    for (Iterator iterator = nodeSet.iterator(); iterator.hasNext();) {
+      NTuple<Descriptor> returnDescTuple = (NTuple<Descriptor>) iterator.next();
+      fg.setReturnFlowNode(returnDescTuple);
+      for (Iterator iterator2 = implicitFlowTupleSet.iterator(); iterator2.hasNext();) {
+        NTuple<Descriptor> implicitFlowDescTuple = (NTuple<Descriptor>) iterator2.next();
+        fg.addValueFlowEdge(implicitFlowDescTuple, returnDescTuple);
+      }
+    }
 
   }
 
@@ -609,7 +1104,7 @@ public class LocationInference {
 
     // note that expression node can create more than one flow node
     // nodeSet contains of flow nodes
-    // base is always assigned to null except name node case!
+    // base is always assigned to null except the case of a name node!
 
     NTuple<Descriptor> flowTuple;
 
@@ -694,15 +1189,12 @@ public class LocationInference {
   private void analyzeFlowTertiaryNode(MethodDescriptor md, SymbolTable nametable, TertiaryNode tn,
       NodeTupleSet nodeSet, NodeTupleSet implicitFlowTupleSet) {
 
-    System.out.println("### analyzeFlowTertiaryNode=" + tn.printNode(0));
-
     NodeTupleSet tertiaryTupleNode = new NodeTupleSet();
     analyzeFlowExpressionNode(md, nametable, tn.getCond(), tertiaryTupleNode, null,
         implicitFlowTupleSet, false);
 
     // add edges from tertiaryTupleNode to all nodes of conditional nodes
     tertiaryTupleNode.addTupleSet(implicitFlowTupleSet);
-    System.out.println("### TertiarayNode's condition=" + tertiaryTupleNode);
     analyzeFlowExpressionNode(md, nametable, tn.getTrueExpr(), tertiaryTupleNode, null,
         implicitFlowTupleSet, false);
 
@@ -743,7 +1235,6 @@ public class LocationInference {
       if (min.getExpression() != null) {
 
         NodeTupleSet baseNodeSet = new NodeTupleSet();
-        System.out.println("Analyzing base of method=" + min.getExpression());
         analyzeFlowExpressionNode(calleeMD, nametable, min.getExpression(), baseNodeSet, null,
             implicitFlowTupleSet, false);
 
@@ -880,17 +1371,13 @@ public class LocationInference {
     NodeTupleSet rightOpSet = new NodeTupleSet();
 
     // left operand
-    System.out.println("Analyzing left op=" + on.getLeft().printNode(0) + "::"
-        + on.getLeft().getClass());
     analyzeFlowExpressionNode(md, nametable, on.getLeft(), leftOpSet, null, implicitFlowTupleSet,
         false);
-    System.out.println("leftOpSet=" + leftOpSet);
 
     if (on.getRight() != null) {
       // right operand
       analyzeFlowExpressionNode(md, nametable, on.getRight(), rightOpSet, null,
           implicitFlowTupleSet, false);
-      System.out.println("rightOpSet=" + rightOpSet);
     }
 
     Operation op = on.getOp();
@@ -1058,6 +1545,7 @@ public class LocationInference {
       base.add(fd);
     }
 
+    getFlowGraph(md).createNewFlowNode(base);
     return base;
 
   }
@@ -1065,8 +1553,6 @@ public class LocationInference {
   private void analyzeFlowAssignmentNode(MethodDescriptor md, SymbolTable nametable,
       AssignmentNode an, NTuple<Descriptor> base, NodeTupleSet implicitFlowTupleSet) {
 
-    System.out.println("analyzeFlowAssignmentNode=" + an);
-
     NodeTupleSet nodeSetRHS = new NodeTupleSet();
     NodeTupleSet nodeSetLHS = new NodeTupleSet();
 
@@ -1081,13 +1567,11 @@ public class LocationInference {
     // and its index value
     analyzeFlowExpressionNode(md, nametable, an.getDest(), nodeSetLHS, null, implicitFlowTupleSet,
         true);
-    System.out.println("ASSIGNMENT NODE nodeSetLHS=" + nodeSetLHS);
 
     if (!postinc) {
       // analyze value flows of rhs expression
       analyzeFlowExpressionNode(md, nametable, an.getSrc(), nodeSetRHS, null, implicitFlowTupleSet,
           false);
-      System.out.println("ASSIGNMENT NODE nodeSetRHS=" + nodeSetRHS);
 
       // creates edges from RHS to LHS
       for (Iterator<NTuple<Descriptor>> iter = nodeSetRHS.iterator(); iter.hasNext();) {
@@ -1122,7 +1606,7 @@ public class LocationInference {
     return mapMethodDescriptorToFlowGraph.get(md);
   }
 
-  public boolean addFlowGraphEdge(MethodDescriptor md, NTuple<Descriptor> from,
+  private boolean addFlowGraphEdge(MethodDescriptor md, NTuple<Descriptor> from,
       NTuple<Descriptor> to) {
     // TODO
     // return true if it adds a new edge
@@ -1147,8 +1631,3 @@ public class LocationInference {
   }
 
 }
-
-class ParamIndexRelation {
-  private Integer higherIdx;
-  private Integer lowerIdx;
-}