Refactor a bunch of includes so that TargetMachine.h doesn't have to include
[oota-llvm.git] / lib / CodeGen / SelectionDAG / ScheduleDAG.cpp
index c4e72072103a8e0b6371d4fac0577cd141c506ff..5100f3a3dcf25dd77ab461b8196191d5981c01be 100644 (file)
@@ -1,8 +1,8 @@
-//===-- ScheduleDAG.cpp - Implement a trivial DAG scheduler ---------------===//
+//===---- ScheduleDAG.cpp - Implement the ScheduleDAG class ---------------===//
 //
 //                     The LLVM Compiler Infrastructure
 //
-// This file was developed by Chris Lattner and is distributed under the
+// This file was developed by James M. Laskey and is distributed under the
 // University of Illinois Open Source License. See LICENSE.TXT for details.
 //
 //===----------------------------------------------------------------------===//
 //===----------------------------------------------------------------------===//
 
 #define DEBUG_TYPE "sched"
+#include "llvm/CodeGen/ScheduleDAG.h"
 #include "llvm/CodeGen/MachineConstantPool.h"
 #include "llvm/CodeGen/MachineFunction.h"
-#include "llvm/CodeGen/SelectionDAGISel.h"
-#include "llvm/CodeGen/SelectionDAG.h"
 #include "llvm/CodeGen/SSARegMap.h"
+#include "llvm/Target/TargetData.h"
 #include "llvm/Target/TargetMachine.h"
 #include "llvm/Target/TargetInstrInfo.h"
 #include "llvm/Target/TargetLowering.h"
-#include "llvm/Support/CommandLine.h"
 #include "llvm/Support/Debug.h"
+#include "llvm/Support/MathExtras.h"
 #include <iostream>
 using namespace llvm;
 
-namespace {
-  // Style of scheduling to use.
-  enum ScheduleChoices {
-    noScheduling,
-    simpleScheduling,
-  };
-} // namespace
-
-cl::opt<ScheduleChoices> ScheduleStyle("sched",
-  cl::desc("Choose scheduling style"),
-  cl::init(noScheduling),
-  cl::values(
-    clEnumValN(noScheduling, "none",
-              "Trivial emission with no analysis"),
-    clEnumValN(simpleScheduling, "simple",
-              "Minimize critical path and maximize processor utilization"),
-   clEnumValEnd));
 
-
-#ifndef NDEBUG
-static cl::opt<bool>
-ViewDAGs("view-sched-dags", cl::Hidden,
-         cl::desc("Pop up a window to show sched dags as they are processed"));
-#else
-static const bool ViewDAGs = 0;
-#endif
-
-namespace {
-//===----------------------------------------------------------------------===//
-///
-/// BitsIterator - Provides iteration through individual bits in a bit vector.
-///
-template<class T>
-class BitsIterator {
-private:
-  T Bits;                               // Bits left to iterate through
-
-public:
-  /// Ctor.
-  BitsIterator(T Initial) : Bits(Initial) {}
+/// BuildSchedUnits - Build SUnits from the selection dag that we are input.
+/// This SUnit graph is similar to the SelectionDAG, but represents flagged
+/// together nodes with a single SUnit.
+void ScheduleDAG::BuildSchedUnits() {
+  // Reserve entries in the vector for each of the SUnits we are creating.  This
+  // ensure that reallocation of the vector won't happen, so SUnit*'s won't get
+  // invalidated.
+  SUnits.reserve(std::distance(DAG.allnodes_begin(), DAG.allnodes_end()));
   
-  /// Next - Returns the next bit set or zero if exhausted.
-  inline T Next() {
-    // Get the rightmost bit set
-    T Result = Bits & -Bits;
-    // Remove from rest
-    Bits &= ~Result;
-    // Return single bit or zero
-    return Result;
-  }
-};
-  
-//===----------------------------------------------------------------------===//
-
-
-//===----------------------------------------------------------------------===//
-///
-/// ResourceTally - Manages the use of resources over time intervals.  Each
-/// item (slot) in the tally vector represents the resources used at a given
-/// moment.  A bit set to 1 indicates that a resource is in use, otherwise
-/// available.  An assumption is made that the tally is large enough to schedule 
-/// all current instructions (asserts otherwise.)
-///
-template<class T>
-class ResourceTally {
-private:
-  std::vector<T> Tally;                 // Resources used per slot
-  typedef typename std::vector<T>::iterator Iter;
-                                        // Tally iterator 
+  const InstrItineraryData &InstrItins = TM.getInstrItineraryData();
   
-  /// AllInUse - Test to see if all of the resources in the slot are busy (set.)
-  inline bool AllInUse(Iter Cursor, unsigned ResourceSet) {
-    return (*Cursor & ResourceSet) == ResourceSet;
-  }
-
-  /// Skip - Skip over slots that use all of the specified resource (all are
-  /// set.)
-  Iter Skip(Iter Cursor, unsigned ResourceSet) {
-    assert(ResourceSet && "At least one resource bit needs to bet set");
+  for (SelectionDAG::allnodes_iterator NI = DAG.allnodes_begin(),
+       E = DAG.allnodes_end(); NI != E; ++NI) {
+    if (isPassiveNode(NI))  // Leaf node, e.g. a TargetImmediate.
+      continue;
+    
+    // If this node has already been processed, stop now.
+    if (SUnitMap[NI]) continue;
     
-    // Continue to the end
-    while (true) {
-      // Break out if one of the resource bits is not set
-      if (!AllInUse(Cursor, ResourceSet)) return Cursor;
-      // Try next slot
-      Cursor++;
-      assert(Cursor < Tally.end() && "Tally is not large enough for schedule");
+    SUnit *NodeSUnit = NewSUnit(NI);
+    
+    // See if anything is flagged to this node, if so, add them to flagged
+    // nodes.  Nodes can have at most one flag input and one flag output.  Flags
+    // are required the be the last operand and result of a node.
+    
+    // Scan up, adding flagged preds to FlaggedNodes.
+    SDNode *N = NI;
+    while (N->getNumOperands() &&
+           N->getOperand(N->getNumOperands()-1).getValueType() == MVT::Flag) {
+      N = N->getOperand(N->getNumOperands()-1).Val;
+      NodeSUnit->FlaggedNodes.push_back(N);
+      SUnitMap[N] = NodeSUnit;
     }
-  }
-  
-  /// FindSlots - Starting from Begin, locate N consecutive slots where at least 
-  /// one of the resource bits is available.  Returns the address of first slot.
-  Iter FindSlots(Iter Begin, unsigned N, unsigned ResourceSet,
-                                         unsigned &Resource) {
-    // Track position      
-    Iter Cursor = Begin;
     
-    // Try all possible slots forward
-    while (true) {
-      // Skip full slots
-      Cursor = Skip(Cursor, ResourceSet);
-      // Determine end of interval
-      Iter End = Cursor + N;
-      assert(End <= Tally.end() && "Tally is not large enough for schedule");
+    // Scan down, adding this node and any flagged succs to FlaggedNodes if they
+    // have a user of the flag operand.
+    N = NI;
+    while (N->getValueType(N->getNumValues()-1) == MVT::Flag) {
+      SDOperand FlagVal(N, N->getNumValues()-1);
       
-      // Iterate thru each resource
-      BitsIterator<T> Resources(ResourceSet & ~*Cursor);
-      while (unsigned Res = Resources.Next()) {
-        // Check if resource is available for next N slots
-        // Break out if resource is busy
-        Iter Interval = Cursor;
-        for (; Interval < End && !(*Interval & Res); Interval++) {}
-        
-        // If available for interval, return where and which resource
-        if (Interval == End) {
-          Resource = Res;
-          return Cursor;
-        }
-        // Otherwise, check if worth checking other resources
-        if (AllInUse(Interval, ResourceSet)) {
-          // Start looking beyond interval
-          Cursor = Interval;
+      // There are either zero or one users of the Flag result.
+      bool HasFlagUse = false;
+      for (SDNode::use_iterator UI = N->use_begin(), E = N->use_end(); 
+           UI != E; ++UI)
+        if (FlagVal.isOperand(*UI)) {
+          HasFlagUse = true;
+          NodeSUnit->FlaggedNodes.push_back(N);
+          SUnitMap[N] = NodeSUnit;
+          N = *UI;
           break;
         }
-      }
-      Cursor++;
-    }
-  }
-  
-  /// Reserve - Mark busy (set) the specified N slots.
-  void Reserve(Iter Begin, unsigned N, unsigned Resource) {
-    // Determine end of interval
-    Iter End = Begin + N;
-    assert(End <= Tally.end() && "Tally is not large enough for schedule");
-    // Set resource bit in each slot
-    for (; Begin < End; Begin++)
-      *Begin |= Resource;
-  }
-
-public:
-  /// Initialize - Resize and zero the tally to the specified number of time
-  /// slots.
-  inline void Initialize(unsigned N) {
-    Tally.assign(N, 0);   // Initialize tally to all zeros.
-  }
-  
-  // FindAndReserve - Locate and mark busy (set) N bits started at slot I, using
-  // ResourceSet for choices.
-  unsigned FindAndReserve(unsigned I, unsigned N, unsigned ResourceSet) {
-    // Which resource used
-    unsigned Resource;
-    // Find slots for instruction.
-    Iter Where = FindSlots(Tally.begin() + I, N, ResourceSet, Resource);
-    // Reserve the slots
-    Reserve(Where, N, Resource);
-    // Return time slot (index)
-    return Where - Tally.begin();
-  }
-
-};
-//===----------------------------------------------------------------------===//
-
-
-//===----------------------------------------------------------------------===//
-// This struct tracks information used to schedule the a node.
-struct ScheduleInfo {
-  SDOperand     Op;                     // Operand information
-  unsigned      Latency;                // Cycles to complete instruction
-  unsigned      ResourceSet;            // Bit vector of usable resources
-  unsigned      Slot;                   // Operand's time slot
-  
-  // Ctor.
-  ScheduleInfo(SDOperand op)
-  : Op(op)
-  , Latency(0)
-  , ResourceSet(0)
-  , Slot(0)
-  {}
-};
-//===----------------------------------------------------------------------===//
-
-
-//===----------------------------------------------------------------------===//
-class SimpleSched {
-private:
-  // TODO - get ResourceSet from TII
-  enum {
-    RSInteger = 0x3,                    // Two integer units
-    RSFloat = 0xC,                      // Two float units
-    RSLoadStore = 0x30,                 // Two load store units
-    RSOther = 0                         // Processing unit independent
-  };
-  
-  MachineBasicBlock *BB;                // Current basic block
-  SelectionDAG &DAG;                    // DAG of the current basic block
-  const TargetMachine &TM;              // Target processor
-  const TargetInstrInfo &TII;           // Target instruction information
-  const MRegisterInfo &MRI;             // Target processor register information
-  SSARegMap *RegMap;                    // Virtual/real register map
-  MachineConstantPool *ConstPool;       // Target constant pool
-  std::vector<ScheduleInfo> Operands;   // All operands to be scheduled
-  std::vector<ScheduleInfo*> Ordering;  // Emit ordering of operands
-  std::map<SDNode *, int> Visited;      // Operands that have been visited
-  ResourceTally<unsigned> Tally;        // Resource usage tally
-  unsigned NSlots;                      // Total latency
-  std::map<SDNode *, unsigned>VRMap;    // Operand to VR map
-  static const unsigned NotFound = ~0U; // Search marker
-  
-public:
-
-  // Ctor.
-  SimpleSched(SelectionDAG &D, MachineBasicBlock *bb)
-    : BB(bb), DAG(D), TM(D.getTarget()), TII(*TM.getInstrInfo()),
-      MRI(*TM.getRegisterInfo()), RegMap(BB->getParent()->getSSARegMap()),
-      ConstPool(BB->getParent()->getConstantPool()),
-      NSlots(0) {
-    assert(&TII && "Target doesn't provide instr info?");
-    assert(&MRI && "Target doesn't provide register info?");
-  }
-  
-  // Run - perform scheduling.
-  MachineBasicBlock *Run() {
-    Schedule();
-    return BB;
-  }
-  
-private:
-  static bool isFlagDefiner(SDOperand Op) { return isFlagDefiner(Op.Val); }
-  static bool isFlagUser(SDOperand Op) { return isFlagUser(Op.Val); }
-  static bool isFlagDefiner(SDNode *A);
-  static bool isFlagUser(SDNode *A);
-  static bool isDefiner(SDNode *A, SDNode *B);
-  static bool isPassiveOperand(SDOperand Op);
-  void IncludeOperand(SDOperand Op);
-  void VisitAll();
-  void Schedule();
-  void GatherOperandInfo();
-  bool isStrongDependency(SDOperand A, SDOperand B) {
-    return isStrongDependency(A.Val, B.Val);
-  }
-  bool isWeakDependency(SDOperand A, SDOperand B) {
-    return isWeakDependency(A.Val, B.Val);
-  }
-  static bool isStrongDependency(SDNode *A, SDNode *B);
-  static bool isWeakDependency(SDNode *A, SDNode *B);
-  void ScheduleBackward();
-  void ScheduleForward();
-  void EmitAll();
-  void EmitFlagUsers(SDOperand Op);
-  static unsigned CountResults(SDOperand Op);
-  static unsigned CountOperands(SDOperand Op);
-  unsigned CreateVirtualRegisters(SDOperand Op, MachineInstr *MI,
-                                  unsigned NumResults,
-                                  const TargetInstrDescriptor &II);
-  unsigned Emit(SDOperand A);
-
-  void printSI(std::ostream &O, ScheduleInfo *SI) const ;
-  void print(std::ostream &O) const ;
-  inline void dump(const char *tag) const { std::cerr << tag; dump(); }
-  void dump() const;
-};
-//===----------------------------------------------------------------------===//
-
-
-//===----------------------------------------------------------------------===//
-class FlagUserIterator {
-private:
-  SDNode               *Definer;        // Node defining flag
-  SDNode::use_iterator UI;              // User node iterator
-  SDNode::use_iterator E;               // End of user nodes
-  unsigned             MinRes;          // Minimum flag result
-
-public:
-  // Ctor.
-  FlagUserIterator(SDNode *D)
-  : Definer(D)
-  , UI(D->use_begin())
-  , E(D->use_end())
-  , MinRes(D->getNumValues()) {
-    // Find minimum flag result.
-    while (MinRes && D->getValueType(MinRes - 1) == MVT::Flag) --MinRes;
-  }
-  
-  /// isFlagUser - Return true if  node uses definer's flag.
-  bool isFlagUser(SDNode *U) {
-    // For each operand (in reverse to only look at flags)
-    for (unsigned N = U->getNumOperands(); 0 < N--;) {
-      // Get operand
-      SDOperand Op = U->getOperand(N);
-      // Not user if there are no flags
-      if (Op.getValueType() != MVT::Flag) return false;
-      // Return true if it is one of the flag results 
-      if (Op.Val == Definer && Op.ResNo >= MinRes) return true;
-    }
-    // Not a flag user
-    return false;
-  }
-  
-  SDNode *next() {
-    // Continue to next user
-    while (UI != E) {
-      // Next user node
-      SDNode *User = *UI++;
-      // Return true if is a flag user
-      if (isFlagUser(User)) return User;
+          if (!HasFlagUse) break;
     }
     
-    // No more user nodes
-    return NULL;
-  }
-};
-
-} // namespace
-
-
-//===----------------------------------------------------------------------===//
-/// isFlagDefiner - Returns true if the operand defines a flag result.
-bool SimpleSched::isFlagDefiner(SDNode *A) {
-  unsigned N = A->getNumValues();
-  return N && A->getValueType(N - 1) == MVT::Flag;
-}
-
-/// isFlagUser - Returns true if the operand uses a flag result.
-///
-bool SimpleSched::isFlagUser(SDNode *A) {
-  unsigned N = A->getNumOperands();
-  return N && A->getOperand(N - 1).getValueType() == MVT::Flag;
-}
-
-/// isDefiner - Return true if Node A is a definder for B.
-///
-bool SimpleSched::isDefiner(SDNode *A, SDNode *B) {
-  for (unsigned i = 0, N = B->getNumOperands(); i < N; i++) {
-    if (B->getOperand(i).Val == A) return true;
-  }
-  return false;
-}
-
-/// isPassiveOperand - Return true if the operand is a non-scheduled leaf
-/// operand.
-bool SimpleSched::isPassiveOperand(SDOperand Op) {
-  if (isa<ConstantSDNode>(Op))       return true;
-  if (isa<RegisterSDNode>(Op))       return true;
-  if (isa<GlobalAddressSDNode>(Op))  return true;
-  if (isa<BasicBlockSDNode>(Op))     return true;
-  if (isa<FrameIndexSDNode>(Op))     return true;
-  if (isa<ConstantPoolSDNode>(Op))   return true;
-  if (isa<ExternalSymbolSDNode>(Op)) return true;
-  return false;
-}
-
-/// IncludeOperand - Add operand to ScheduleInfo vector.
-///
-void SimpleSched::IncludeOperand(SDOperand Op) {
-  // Ignore entry node
-  if (Op.getOpcode() == ISD::EntryToken) return;
-  // Check current count for operand
-  int Count = Visited[Op.Val];
-  // If the operand is already in list
-  if (Count < 0) return;
-  // If this the first time then get count 
-  if (!Count) Count = Op.Val->use_size();
-  // Decrement count to indicate a visit
-  Count--;
-  // If count has gone to zero then add operand to list
-  if (!Count) {
-    // Add operand
-    Operands.push_back(ScheduleInfo(Op));
-    // indicate operand has been added
-    Count--;
-  }
-  // Mark as visited with new count 
-  Visited[Op.Val] = Count;
-}
-
-/// VisitAll - Visit each operand breadth-wise to produce an initial ordering.
-/// Note that the ordering in the Operands vector is reversed.
-void SimpleSched::VisitAll() {
-  // Add first element to list
-  Operands.push_back(DAG.getRoot());
-  for (unsigned i = 0; i < Operands.size(); i++) { // note: size() varies
-    // Get next operand. Need copy because Operands vector is growing and
-    // addresses can be ScheduleInfo changing.
-    SDOperand Op = Operands[i].Op;
-    // Get the number of real operands
-    unsigned NodeOperands = CountOperands(Op);
-    // Get the total number of operands
-    unsigned NumOperands = Op.getNumOperands();
-
-    // Visit all operands skipping the Other operand if present
-    for (unsigned i = NumOperands; 0 < i--;) {
-      SDOperand OpI = Op.getOperand(i);
-      // Ignore passive operands
-      if (isPassiveOperand(OpI)) continue;
-      // Check out operand
-      IncludeOperand(OpI);
-    }
-  }
-
-  // Add entry node last (IncludeOperand filters entry nodes)
-  if (DAG.getEntryNode().Val != DAG.getRoot().Val)
-    Operands.push_back(DAG.getEntryNode());
-}
-
-/// GatherOperandInfo - Get latency and resource information about each operand.
-///
-void SimpleSched::GatherOperandInfo() {
-  // Add addresses of operand info to ordering vector
-  // Get number of operands
-  unsigned N = Operands.size();
-  // FIXME: This is an ugly (but temporary!) hack to test the scheduler before
-  // we have real target info.
-  
-  // For each operand being scheduled
-  for (unsigned i = 0; i < N; i++) {
-    ScheduleInfo* SI = &Operands[N - i - 1];
-    SDOperand Op = SI->Op;
-    MVT::ValueType VT = Op.Val->getValueType(0);
-    if (Op.isTargetOpcode()) {
-      MachineOpCode TOpc = Op.getTargetOpcode();
-      // FIXME SI->Latency = std::max(1, TII.maxLatency(TOpc));
-      // FIXME SI->ResourceSet = TII.resources(TOpc);
-      if (TII.isCall(TOpc)) {
-        SI->ResourceSet = RSInteger;
-        SI->Latency = 40;
-      } else if (TII.isLoad(TOpc)) {
-        SI->ResourceSet = RSLoadStore;
-        SI->Latency = 5;
-      } else if (TII.isStore(TOpc)) {
-        SI->ResourceSet = RSLoadStore;
-        SI->Latency = 2;
-      } else if (MVT::isInteger(VT)) {
-        SI->ResourceSet = RSInteger;
-        SI->Latency = 2;
-      } else if (MVT::isFloatingPoint(VT)) {
-        SI->ResourceSet = RSFloat;
-        SI->Latency = 3;
-      } else {
-        SI->ResourceSet = RSOther;
-        SI->Latency = 0;
-      }
+    // Now all flagged nodes are in FlaggedNodes and N is the bottom-most node.
+    // Update the SUnit
+    NodeSUnit->Node = N;
+    SUnitMap[N] = NodeSUnit;
+    
+    // Compute the latency for the node.  We use the sum of the latencies for
+    // all nodes flagged together into this SUnit.
+    if (InstrItins.isEmpty()) {
+      // No latency information.
+      NodeSUnit->Latency = 1;
     } else {
-      if (MVT::isInteger(VT)) {
-        SI->ResourceSet = RSInteger;
-        SI->Latency = 2;
-      } else if (MVT::isFloatingPoint(VT)) {
-        SI->ResourceSet = RSFloat;
-        SI->Latency = 3;
-      } else {
-        SI->ResourceSet = RSOther;
-        SI->Latency = 0;
+      NodeSUnit->Latency = 0;
+      if (N->isTargetOpcode()) {
+        unsigned SchedClass = TII->getSchedClass(N->getTargetOpcode());
+        InstrStage *S = InstrItins.begin(SchedClass);
+        InstrStage *E = InstrItins.end(SchedClass);
+        for (; S != E; ++S)
+          NodeSUnit->Latency += S->Cycles;
+      }
+      for (unsigned i = 0, e = NodeSUnit->FlaggedNodes.size(); i != e; ++i) {
+        SDNode *FNode = NodeSUnit->FlaggedNodes[i];
+        if (FNode->isTargetOpcode()) {
+          unsigned SchedClass = TII->getSchedClass(FNode->getTargetOpcode());
+          InstrStage *S = InstrItins.begin(SchedClass);
+          InstrStage *E = InstrItins.end(SchedClass);
+          for (; S != E; ++S)
+            NodeSUnit->Latency += S->Cycles;
+        }
       }
-    }
-    
-    // Add one slot for the instruction itself
-    SI->Latency++;
-    
-    // Sum up all the latencies for max tally size
-    NSlots += SI->Latency;
-    
-    // Place in initial sorted order
-    // FIXME - PUNT - ignore flag users 
-    if (!isFlagUser(Op)) Ordering.push_back(SI);
-  }
-}
-
-/// isStrongDependency - Return true if operand A has results used by operand B. 
-/// I.E., B must wait for latency of A.
-bool SimpleSched::isStrongDependency(SDNode *A, SDNode *B) {
-  // If A defines for B then it's a strong dependency
-  if (isDefiner(A, B)) return true;
-  // If A defines a flag then it's users are part of the dependency
-  if (isFlagDefiner(A)) {
-    // Check each flag user
-    FlagUserIterator FI(A);
-    while (SDNode *User = FI.next()) {
-      // If flag user has strong dependency so does B
-      if (isStrongDependency(User, B)) return true;
-    }
-  }
-  // If B defines a flag then it's users are part of the dependency
-  if (isFlagDefiner(B)) {
-    // Check each flag user
-    FlagUserIterator FI(B);
-    while (SDNode *User = FI.next()) {
-      // If flag user has strong dependency so does B
-      if (isStrongDependency(A, User)) return true;
     }
   }
-  return false;
-}
-
-/// isWeakDependency Return true if operand A produces a result that will
-/// conflict with operands of B.
-bool SimpleSched::isWeakDependency(SDNode *A, SDNode *B) {
-  // TODO check for conflicting real registers and aliases
-#if 0 // Since we are in SSA form and not checking register aliasing
-  return A->getOpcode() == ISD::EntryToken || isStrongDependency(B, A);
-#else
-  return A->getOpcode() == ISD::EntryToken;
-#endif
-}
-
-/// ScheduleBackward - Schedule instructions so that any long latency
-/// instructions and the critical path get pushed back in time. Time is run in
-/// reverse to allow code reuse of the Tally and eliminate the overhead of
-/// biasing every slot indices against NSlots.
-void SimpleSched::ScheduleBackward() {
-  // Size and clear the resource tally
-  Tally.Initialize(NSlots);
-  // Get number of operands to schedule
-  unsigned N = Ordering.size();
   
-  // For each operand being scheduled
-  for (unsigned i = N; 0 < i--;) {
-    ScheduleInfo *SI = Ordering[i];
-    // Track insertion
-    unsigned Slot = NotFound;
+  // Pass 2: add the preds, succs, etc.
+  for (unsigned su = 0, e = SUnits.size(); su != e; ++su) {
+    SUnit *SU = &SUnits[su];
+    SDNode *MainNode = SU->Node;
     
-    // Compare against those previously scheduled operands
-    for (unsigned j = i + 1; j < N; j++) {
-      // Get following instruction
-      ScheduleInfo *Other = Ordering[j];
-      
-      // Check dependency against previously inserted operands
-      if (isStrongDependency(SI->Op, Other->Op)) {
-        Slot = Other->Slot + Other->Latency;
-        break;
-      } else if (isWeakDependency(SI->Op, Other->Op)) {
-        Slot = Other->Slot;
-        break;
-      }
+    if (MainNode->isTargetOpcode()) {
+      unsigned Opc = MainNode->getTargetOpcode();
+      if (TII->isTwoAddrInstr(Opc))
+        SU->isTwoAddress = true;
+      if (TII->isCommutableInstr(Opc))
+        SU->isCommutable = true;
     }
     
-    // If independent of others (or first entry)
-    if (Slot == NotFound) Slot = 0;
+    // Find all predecessors and successors of the group.
+    // Temporarily add N to make code simpler.
+    SU->FlaggedNodes.push_back(MainNode);
     
-    // Find a slot where the needed resources are available
-    if (SI->ResourceSet)
-      Slot = Tally.FindAndReserve(Slot, SI->Latency, SI->ResourceSet);
+    for (unsigned n = 0, e = SU->FlaggedNodes.size(); n != e; ++n) {
+      SDNode *N = SU->FlaggedNodes[n];
       
-    // Set operand slot
-    SI->Slot = Slot;
-    
-    // Insert sort based on slot
-    unsigned j = i + 1;
-    for (; j < N; j++) {
-      // Get following instruction
-      ScheduleInfo *Other = Ordering[j];
-      // Should we look further
-      if (Slot >= Other->Slot) break;
-      // Shuffle other into ordering
-      Ordering[j - 1] = Other;
-    }
-    // Insert operand in proper slot
-    if (j != i + 1) Ordering[j - 1] = SI;
-  }
-}
-
-/// ScheduleForward - Schedule instructions to maximize packing.
-///
-void SimpleSched::ScheduleForward() {
-  // Size and clear the resource tally
-  Tally.Initialize(NSlots);
-  // Get number of operands to schedule
-  unsigned N = Ordering.size();
-  
-  // For each operand being scheduled
-  for (unsigned i = 0; i < N; i++) {
-    ScheduleInfo *SI = Ordering[i];
-    // Track insertion
-    unsigned Slot = NotFound;
-    
-    // Compare against those previously scheduled operands
-    for (unsigned j = i; 0 < j--;) {
-      // Get following instruction
-      ScheduleInfo *Other = Ordering[j];
-      
-      // Check dependency against previously inserted operands
-      if (isStrongDependency(Other->Op, SI->Op)) {
-        Slot = Other->Slot + Other->Latency;
-        break;
-      } else if (isWeakDependency(Other->Op, SI->Op)) {
-        Slot = Other->Slot;
-        break;
+      for (unsigned i = 0, e = N->getNumOperands(); i != e; ++i) {
+        SDNode *OpN = N->getOperand(i).Val;
+        if (isPassiveNode(OpN)) continue;   // Not scheduled.
+        SUnit *OpSU = SUnitMap[OpN];
+        assert(OpSU && "Node has no SUnit!");
+        if (OpSU == SU) continue;           // In the same group.
+
+        MVT::ValueType OpVT = N->getOperand(i).getValueType();
+        assert(OpVT != MVT::Flag && "Flagged nodes should be in same sunit!");
+        bool isChain = OpVT == MVT::Other;
+        
+        if (SU->Preds.insert(std::make_pair(OpSU, isChain)).second) {
+          if (!isChain) {
+            SU->NumPreds++;
+            SU->NumPredsLeft++;
+          } else {
+            SU->NumChainPredsLeft++;
+          }
+        }
+        if (OpSU->Succs.insert(std::make_pair(SU, isChain)).second) {
+          if (!isChain) {
+            OpSU->NumSuccs++;
+            OpSU->NumSuccsLeft++;
+          } else {
+            OpSU->NumChainSuccsLeft++;
+          }
+        }
       }
     }
     
-    // If independent of others (or first entry)
-    if (Slot == NotFound) Slot = 0;
-    
-    // Find a slot where the needed resources are available
-    if (SI->ResourceSet)
-      Slot = Tally.FindAndReserve(Slot, SI->Latency, SI->ResourceSet);
-      
-    // Set operand slot
-    SI->Slot = Slot;
-    
-    // Insert sort based on slot
-    unsigned j = i;
-    for (; 0 < j--;) {
-      // Get following instruction
-      ScheduleInfo *Other = Ordering[j];
-      // Should we look further
-      if (Slot >= Other->Slot) break;
-      // Shuffle other into ordering
-      Ordering[j + 1] = Other;
-    }
-    // Insert operand in proper slot
-    if (j != i) Ordering[j + 1] = SI;
+    // Remove MainNode from FlaggedNodes again.
+    SU->FlaggedNodes.pop_back();
   }
+  
+  return;
 }
 
-/// EmitAll - Emit all operands in schedule sorted order.
-///
-void SimpleSched::EmitAll() {
-  // For each operand in the ordering
-  for (unsigned i = 0, N = Ordering.size(); i < N; i++) {
-    // Get the scheduling info
-    ScheduleInfo *SI = Ordering[i];
-    // Get the operand
-    SDOperand Op = SI->Op;
-    // Emit the operand
-    Emit(Op);
-    // FIXME - PUNT - If Op defines a flag then it's users need to be emitted now
-    if (isFlagDefiner(Op)) EmitFlagUsers(Op);
+static void CalculateDepths(SUnit *SU, unsigned Depth, unsigned Max) {
+  if (Depth > SU->Depth) {
+    SU->Depth = Depth;
+    for (std::set<std::pair<SUnit*, bool> >::iterator I = SU->Succs.begin(),
+           E = SU->Succs.end(); I != E; ++I)
+      CalculateDepths(I->first, Depth+1, Max);
   }
 }
 
-/// EmitFlagUsers - Emit users of operands flag.
-///
-void SimpleSched::EmitFlagUsers(SDOperand Op) {
-  // Check each flag user
-  FlagUserIterator FI(Op.Val);
-  while (SDNode *User = FI.next()) {
-    // Construct user node as operand
-    SDOperand OpU(User, 0);
-    // Emit  user node
-    Emit(OpU);
-    // If user defines a flag then it's users need to be emitted now
-    if (isFlagDefiner(User)) EmitFlagUsers(OpU);
+void ScheduleDAG::CalculateDepths() {
+  SUnit *Entry = SUnitMap[DAG.getEntryNode().Val];
+  ::CalculateDepths(Entry, 0U, SUnits.size());
+  for (unsigned i = 0, e = SUnits.size(); i != e; ++i)
+    if (SUnits[i].Preds.size() == 0 && &SUnits[i] != Entry) {
+      ::CalculateDepths(&SUnits[i], 0U, SUnits.size());
+    }
+}
+
+static void CalculateHeights(SUnit *SU, unsigned Height) {
+  if (Height > SU->Height) {
+    SU->Height = Height;
+    for (std::set<std::pair<SUnit*, bool> >::iterator I = SU->Preds.begin(),
+           E = SU->Preds.end(); I != E; ++I)
+      CalculateHeights(I->first, Height+1);
   }
 }
+void ScheduleDAG::CalculateHeights() {
+  SUnit *Root = SUnitMap[DAG.getRoot().Val];
+  ::CalculateHeights(Root, 0U);
+}
 
 /// CountResults - The results of target nodes have register or immediate
 /// operands first, then an optional chain, and optional flag operands (which do
 /// not go into the machine instrs.)
-unsigned SimpleSched::CountResults(SDOperand Op) {
-  unsigned N = Op.Val->getNumValues();
-  while (N && Op.Val->getValueType(N - 1) == MVT::Flag)
+static unsigned CountResults(SDNode *Node) {
+  unsigned N = Node->getNumValues();
+  while (N && Node->getValueType(N - 1) == MVT::Flag)
     --N;
-  if (N && Op.Val->getValueType(N - 1) == MVT::Other)
+  if (N && Node->getValueType(N - 1) == MVT::Other)
     --N;    // Skip over chain result.
   return N;
 }
@@ -687,20 +217,19 @@ unsigned SimpleSched::CountResults(SDOperand Op) {
 /// CountOperands  The inputs to target nodes have any actual inputs first,
 /// followed by an optional chain operand, then flag operands.  Compute the
 /// number of actual operands that  will go into the machine instr.
-unsigned SimpleSched::CountOperands(SDOperand Op) {
-  unsigned N = Op.getNumOperands();
-  while (N && Op.getOperand(N - 1).getValueType() == MVT::Flag)
+static unsigned CountOperands(SDNode *Node) {
+  unsigned N = Node->getNumOperands();
+  while (N && Node->getOperand(N - 1).getValueType() == MVT::Flag)
     --N;
-  if (N && Op.getOperand(N - 1).getValueType() == MVT::Other)
+  if (N && Node->getOperand(N - 1).getValueType() == MVT::Other)
     --N; // Ignore chain if it exists.
   return N;
 }
 
-/// CreateVirtualRegisters - Add result register values for things that are
-/// defined by this instruction.
-unsigned SimpleSched::CreateVirtualRegisters(SDOperand Op, MachineInstr *MI,
-                                             unsigned NumResults,
-                                             const TargetInstrDescriptor &II) {
+static unsigned CreateVirtualRegisters(MachineInstr *MI,
+                                       unsigned NumResults,
+                                       SSARegMap *RegMap,
+                                       const TargetInstrDescriptor &II) {
   // Create the result registers for this node and add the result regs to
   // the machine instruction.
   const TargetOperandInfo *OpInfo = II.OpInfo;
@@ -708,27 +237,124 @@ unsigned SimpleSched::CreateVirtualRegisters(SDOperand Op, MachineInstr *MI,
   MI->addRegOperand(ResultReg, MachineOperand::Def);
   for (unsigned i = 1; i != NumResults; ++i) {
     assert(OpInfo[i].RegClass && "Isn't a register operand!");
-    MI->addRegOperand(RegMap->createVirtualRegister(OpInfo[0].RegClass),
+    MI->addRegOperand(RegMap->createVirtualRegister(OpInfo[i].RegClass),
                       MachineOperand::Def);
   }
   return ResultReg;
 }
 
-/// Emit - Generate machine code for an operand and needed dependencies.
+/// getVR - Return the virtual register corresponding to the specified result
+/// of the specified node.
+static unsigned getVR(SDOperand Op, std::map<SDNode*, unsigned> &VRBaseMap) {
+  std::map<SDNode*, unsigned>::iterator I = VRBaseMap.find(Op.Val);
+  assert(I != VRBaseMap.end() && "Node emitted out of order - late");
+  return I->second + Op.ResNo;
+}
+
+
+/// AddOperand - Add the specified operand to the specified machine instr.  II
+/// specifies the instruction information for the node, and IIOpNum is the
+/// operand number (in the II) that we are adding. IIOpNum and II are used for 
+/// assertions only.
+void ScheduleDAG::AddOperand(MachineInstr *MI, SDOperand Op,
+                             unsigned IIOpNum,
+                             const TargetInstrDescriptor *II,
+                             std::map<SDNode*, unsigned> &VRBaseMap) {
+  if (Op.isTargetOpcode()) {
+    // Note that this case is redundant with the final else block, but we
+    // include it because it is the most common and it makes the logic
+    // simpler here.
+    assert(Op.getValueType() != MVT::Other &&
+           Op.getValueType() != MVT::Flag &&
+           "Chain and flag operands should occur at end of operand list!");
+    
+    // Get/emit the operand.
+    unsigned VReg = getVR(Op, VRBaseMap);
+    MI->addRegOperand(VReg, MachineOperand::Use);
+    
+    // Verify that it is right.
+    assert(MRegisterInfo::isVirtualRegister(VReg) && "Not a vreg?");
+    if (II) {
+      assert(II->OpInfo[IIOpNum].RegClass &&
+             "Don't have operand info for this instruction!");
+      assert(RegMap->getRegClass(VReg) == II->OpInfo[IIOpNum].RegClass &&
+             "Register class of operand and regclass of use don't agree!");
+    }
+  } else if (ConstantSDNode *C =
+             dyn_cast<ConstantSDNode>(Op)) {
+    MI->addImmOperand(C->getValue());
+  } else if (RegisterSDNode*R =
+             dyn_cast<RegisterSDNode>(Op)) {
+    MI->addRegOperand(R->getReg(), MachineOperand::Use);
+  } else if (GlobalAddressSDNode *TGA =
+             dyn_cast<GlobalAddressSDNode>(Op)) {
+    MI->addGlobalAddressOperand(TGA->getGlobal(), TGA->getOffset());
+  } else if (BasicBlockSDNode *BB =
+             dyn_cast<BasicBlockSDNode>(Op)) {
+    MI->addMachineBasicBlockOperand(BB->getBasicBlock());
+  } else if (FrameIndexSDNode *FI =
+             dyn_cast<FrameIndexSDNode>(Op)) {
+    MI->addFrameIndexOperand(FI->getIndex());
+  } else if (JumpTableSDNode *JT =
+             dyn_cast<JumpTableSDNode>(Op)) {
+    MI->addJumpTableIndexOperand(JT->getIndex());
+  } else if (ConstantPoolSDNode *CP = 
+             dyn_cast<ConstantPoolSDNode>(Op)) {
+    int Offset = CP->getOffset();
+    unsigned Align = CP->getAlignment();
+    // MachineConstantPool wants an explicit alignment.
+    if (Align == 0) {
+      if (CP->get()->getType() == Type::DoubleTy)
+        Align = 3;  // always 8-byte align doubles.
+      else {
+        Align = TM.getTargetData()
+          ->getTypeAlignmentShift(CP->get()->getType());
+        if (Align == 0) {
+          // Alignment of packed types.  FIXME!
+          Align = TM.getTargetData()->getTypeSize(CP->get()->getType());
+          Align = Log2_64(Align);
+        }
+      }
+    }
+    
+    unsigned Idx = ConstPool->getConstantPoolIndex(CP->get(), Align);
+    MI->addConstantPoolIndexOperand(Idx, Offset);
+  } else if (ExternalSymbolSDNode *ES = 
+             dyn_cast<ExternalSymbolSDNode>(Op)) {
+    MI->addExternalSymbolOperand(ES->getSymbol());
+  } else {
+    assert(Op.getValueType() != MVT::Other &&
+           Op.getValueType() != MVT::Flag &&
+           "Chain and flag operands should occur at end of operand list!");
+    unsigned VReg = getVR(Op, VRBaseMap);
+    MI->addRegOperand(VReg, MachineOperand::Use);
+    
+    // Verify that it is right.
+    assert(MRegisterInfo::isVirtualRegister(VReg) && "Not a vreg?");
+    if (II) {
+      assert(II->OpInfo[IIOpNum].RegClass &&
+             "Don't have operand info for this instruction!");
+      assert(RegMap->getRegClass(VReg) == II->OpInfo[IIOpNum].RegClass &&
+             "Register class of operand and regclass of use don't agree!");
+    }
+  }
+  
+}
+
+
+/// EmitNode - Generate machine code for an node and needed dependencies.
 ///
-unsigned SimpleSched::Emit(SDOperand Op) {
-  std::map<SDNode *, unsigned>::iterator OpI = VRMap.lower_bound(Op.Val);
-  if (OpI != VRMap.end() && OpI->first == Op.Val)
-    return OpI->second + Op.ResNo;
-  unsigned &OpSlot = VRMap.insert(OpI, std::make_pair(Op.Val, 0))->second;
+void ScheduleDAG::EmitNode(SDNode *Node, 
+                           std::map<SDNode*, unsigned> &VRBaseMap) {
+  unsigned VRBase = 0;                 // First virtual register for node
   
-  unsigned ResultReg = 0;
-  if (Op.isTargetOpcode()) {
-    unsigned Opc = Op.getTargetOpcode();
-    const TargetInstrDescriptor &II = TII.get(Opc);
+  // If machine instruction
+  if (Node->isTargetOpcode()) {
+    unsigned Opc = Node->getTargetOpcode();
+    const TargetInstrDescriptor &II = TII->get(Opc);
 
-    unsigned NumResults = CountResults(Op);
-    unsigned NodeOperands = CountOperands(Op);
+    unsigned NumResults = CountResults(Node);
+    unsigned NodeOperands = CountOperands(Node);
     unsigned NumMIOperands = NodeOperands + NumResults;
 #ifndef NDEBUG
     assert((unsigned(II.numOperands) == NumMIOperands || II.numOperands == -1)&&
@@ -736,73 +362,49 @@ unsigned SimpleSched::Emit(SDOperand Op) {
 #endif
 
     // Create the new machine instruction.
-    MachineInstr *MI = new MachineInstr(Opc, NumMIOperands, true, true);
+    MachineInstr *MI = new MachineInstr(Opc, NumMIOperands);
     
     // Add result register values for things that are defined by this
     // instruction.
-    if (NumResults) ResultReg = CreateVirtualRegisters(Op, MI, NumResults, II);
     
-    // If there is a token chain operand, emit it first, as a hack to get avoid
-    // really bad cases.
-    if (Op.getNumOperands() > NodeOperands &&
-        Op.getOperand(NodeOperands).getValueType() == MVT::Other) {
-      Emit(Op.getOperand(NodeOperands));
+    // If the node is only used by a CopyToReg and the dest reg is a vreg, use
+    // the CopyToReg'd destination register instead of creating a new vreg.
+    if (NumResults == 1) {
+      for (SDNode::use_iterator UI = Node->use_begin(), E = Node->use_end();
+           UI != E; ++UI) {
+        SDNode *Use = *UI;
+        if (Use->getOpcode() == ISD::CopyToReg && 
+            Use->getOperand(2).Val == Node) {
+          unsigned Reg = cast<RegisterSDNode>(Use->getOperand(1))->getReg();
+          if (MRegisterInfo::isVirtualRegister(Reg)) {
+            VRBase = Reg;
+            MI->addRegOperand(Reg, MachineOperand::Def);
+            break;
+          }
+        }
+      }
     }
     
+    // Otherwise, create new virtual registers.
+    if (NumResults && VRBase == 0)
+      VRBase = CreateVirtualRegisters(MI, NumResults, RegMap, II);
+    
     // Emit all of the actual operands of this instruction, adding them to the
     // instruction as appropriate.
-    for (unsigned i = 0; i != NodeOperands; ++i) {
-      if (Op.getOperand(i).isTargetOpcode()) {
-        // Note that this case is redundant with the final else block, but we
-        // include it because it is the most common and it makes the logic
-        // simpler here.
-        assert(Op.getOperand(i).getValueType() != MVT::Other &&
-               Op.getOperand(i).getValueType() != MVT::Flag &&
-               "Chain and flag operands should occur at end of operand list!");
-        
-        MI->addRegOperand(Emit(Op.getOperand(i)), MachineOperand::Use);
-      } else if (ConstantSDNode *C =
-                                   dyn_cast<ConstantSDNode>(Op.getOperand(i))) {
-        MI->addZeroExtImm64Operand(C->getValue());
-      } else if (RegisterSDNode*R =dyn_cast<RegisterSDNode>(Op.getOperand(i))) {
-        MI->addRegOperand(R->getReg(), MachineOperand::Use);
-      } else if (GlobalAddressSDNode *TGA =
-                       dyn_cast<GlobalAddressSDNode>(Op.getOperand(i))) {
-        MI->addGlobalAddressOperand(TGA->getGlobal(), false, 0);
-      } else if (BasicBlockSDNode *BB =
-                       dyn_cast<BasicBlockSDNode>(Op.getOperand(i))) {
-        MI->addMachineBasicBlockOperand(BB->getBasicBlock());
-      } else if (FrameIndexSDNode *FI =
-                       dyn_cast<FrameIndexSDNode>(Op.getOperand(i))) {
-        MI->addFrameIndexOperand(FI->getIndex());
-      } else if (ConstantPoolSDNode *CP = 
-                    dyn_cast<ConstantPoolSDNode>(Op.getOperand(i))) {
-        unsigned Idx = ConstPool->getConstantPoolIndex(CP->get());
-        MI->addConstantPoolIndexOperand(Idx);
-      } else if (ExternalSymbolSDNode *ES = 
-                 dyn_cast<ExternalSymbolSDNode>(Op.getOperand(i))) {
-        MI->addExternalSymbolOperand(ES->getSymbol(), false);
-      } else {
-        assert(Op.getOperand(i).getValueType() != MVT::Other &&
-               Op.getOperand(i).getValueType() != MVT::Flag &&
-               "Chain and flag operands should occur at end of operand list!");
-        MI->addRegOperand(Emit(Op.getOperand(i)), MachineOperand::Use);
+    for (unsigned i = 0; i != NodeOperands; ++i)
+      AddOperand(MI, Node->getOperand(i), i+NumResults, &II, VRBaseMap);
+
+    // Commute node if it has been determined to be profitable.
+    if (CommuteSet.count(Node)) {
+      MachineInstr *NewMI = TII->commuteInstruction(MI);
+      if (NewMI == 0)
+        DEBUG(std::cerr << "Sched: COMMUTING FAILED!\n");
+      else {
+        DEBUG(std::cerr << "Sched: COMMUTED TO: " << *NewMI);
+        MI = NewMI;
       }
     }
 
-    // Finally, if this node has any flag operands, we *must* emit them last, to
-    // avoid emitting operations that might clobber the flags.
-    if (Op.getNumOperands() > NodeOperands) {
-      unsigned i = NodeOperands;
-      if (Op.getOperand(i).getValueType() == MVT::Other)
-        ++i;  // the chain is already selected.
-      for (unsigned N = Op.getNumOperands(); i < N; i++) {
-        assert(Op.getOperand(i).getValueType() == MVT::Flag &&
-               "Must be flag operands!");
-        Emit(Op.getOperand(i));
-      }
-    }
-    
     // Now that we have emitted all operands, emit this instruction itself.
     if ((II.Flags & M_USES_CUSTOM_DAG_SCHED_INSERTION) == 0) {
       BB->insert(BB->end(), MI);
@@ -812,138 +414,214 @@ unsigned SimpleSched::Emit(SDOperand Op) {
       BB = DAG.getTargetLoweringInfo().InsertAtEndOfBasicBlock(MI, BB);
     }
   } else {
-    switch (Op.getOpcode()) {
+    switch (Node->getOpcode()) {
     default:
-      Op.Val->dump(); 
+      Node->dump(); 
       assert(0 && "This target-independent node should have been selected!");
-    case ISD::EntryToken: break;
+    case ISD::EntryToken: // fall thru
     case ISD::TokenFactor:
-      for (unsigned i = 0, N = Op.getNumOperands(); i < N; i++) {
-        Emit(Op.getOperand(i));
-      }
       break;
     case ISD::CopyToReg: {
-      SDOperand FlagOp;
-      if (Op.getNumOperands() == 4) {
-        FlagOp = Op.getOperand(3);
-      }
-      if (Op.getOperand(0).Val != FlagOp.Val) {
-        Emit(Op.getOperand(0));   // Emit the chain.
-      }
-      unsigned Val = Emit(Op.getOperand(2));
-      if (FlagOp.Val) {
-        Emit(FlagOp);
-      }
-      MRI.copyRegToReg(*BB, BB->end(),
-                       cast<RegisterSDNode>(Op.getOperand(1))->getReg(), Val,
-                       RegMap->getRegClass(Val));
+      unsigned InReg = getVR(Node->getOperand(2), VRBaseMap);
+      unsigned DestReg = cast<RegisterSDNode>(Node->getOperand(1))->getReg();
+      if (InReg != DestReg)   // Coalesced away the copy?
+        MRI->copyRegToReg(*BB, BB->end(), DestReg, InReg,
+                          RegMap->getRegClass(InReg));
       break;
     }
     case ISD::CopyFromReg: {
-      Emit(Op.getOperand(0));   // Emit the chain.
-      unsigned SrcReg = cast<RegisterSDNode>(Op.getOperand(1))->getReg();
-      
+      unsigned SrcReg = cast<RegisterSDNode>(Node->getOperand(1))->getReg();
+      if (MRegisterInfo::isVirtualRegister(SrcReg)) {
+        VRBase = SrcReg;  // Just use the input register directly!
+        break;
+      }
+
+      // If the node is only used by a CopyToReg and the dest reg is a vreg, use
+      // the CopyToReg'd destination register instead of creating a new vreg.
+      for (SDNode::use_iterator UI = Node->use_begin(), E = Node->use_end();
+           UI != E; ++UI) {
+        SDNode *Use = *UI;
+        if (Use->getOpcode() == ISD::CopyToReg && 
+            Use->getOperand(2).Val == Node) {
+          unsigned DestReg = cast<RegisterSDNode>(Use->getOperand(1))->getReg();
+          if (MRegisterInfo::isVirtualRegister(DestReg)) {
+            VRBase = DestReg;
+            break;
+          }
+        }
+      }
+
       // Figure out the register class to create for the destreg.
       const TargetRegisterClass *TRC = 0;
-      if (MRegisterInfo::isVirtualRegister(SrcReg)) {
-        TRC = RegMap->getRegClass(SrcReg);
+      if (VRBase) {
+        TRC = RegMap->getRegClass(VRBase);
       } else {
-        // FIXME: we don't know what register class to generate this for.  Do
-        // a brute force search and pick the first match. :(
-        for (MRegisterInfo::regclass_iterator I = MRI.regclass_begin(),
-               E = MRI.regclass_end(); I != E; ++I)
-          if ((*I)->contains(SrcReg)) {
+
+        // Pick the register class of the right type that contains this physreg.
+        for (MRegisterInfo::regclass_iterator I = MRI->regclass_begin(),
+             E = MRI->regclass_end(); I != E; ++I)
+          if ((*I)->hasType(Node->getValueType(0)) &&
+              (*I)->contains(SrcReg)) {
             TRC = *I;
             break;
           }
         assert(TRC && "Couldn't find register class for reg copy!");
+      
+        // Create the reg, emit the copy.
+        VRBase = RegMap->createVirtualRegister(TRC);
       }
+      MRI->copyRegToReg(*BB, BB->end(), VRBase, SrcReg, TRC);
+      break;
+    }
+    case ISD::INLINEASM: {
+      unsigned NumOps = Node->getNumOperands();
+      if (Node->getOperand(NumOps-1).getValueType() == MVT::Flag)
+        --NumOps;  // Ignore the flag operand.
       
-      // Create the reg, emit the copy.
-      ResultReg = RegMap->createVirtualRegister(TRC);
-      MRI.copyRegToReg(*BB, BB->end(), ResultReg, SrcReg, TRC);
+      // Create the inline asm machine instruction.
+      MachineInstr *MI =
+        new MachineInstr(BB, TargetInstrInfo::INLINEASM, (NumOps-2)/2+1);
+
+      // Add the asm string as an external symbol operand.
+      const char *AsmStr =
+        cast<ExternalSymbolSDNode>(Node->getOperand(1))->getSymbol();
+      MI->addExternalSymbolOperand(AsmStr);
+      
+      // Add all of the operand registers to the instruction.
+      for (unsigned i = 2; i != NumOps;) {
+        unsigned Flags = cast<ConstantSDNode>(Node->getOperand(i))->getValue();
+        unsigned NumVals = Flags >> 3;
+        
+        MI->addImmOperand(Flags);
+        ++i;  // Skip the ID value.
+        
+        switch (Flags & 7) {
+        default: assert(0 && "Bad flags!");
+        case 1:  // Use of register.
+          for (; NumVals; --NumVals, ++i) {
+            unsigned Reg = cast<RegisterSDNode>(Node->getOperand(i))->getReg();
+            MI->addRegOperand(Reg, MachineOperand::Use);
+          }
+          break;
+        case 2:   // Def of register.
+          for (; NumVals; --NumVals, ++i) {
+            unsigned Reg = cast<RegisterSDNode>(Node->getOperand(i))->getReg();
+            MI->addRegOperand(Reg, MachineOperand::Def);
+          }
+          break;
+        case 3: { // Immediate.
+          assert(NumVals == 1 && "Unknown immediate value!");
+          uint64_t Val = cast<ConstantSDNode>(Node->getOperand(i))->getValue();
+          MI->addImmOperand(Val);
+          ++i;
+          break;
+        }
+        case 4:  // Addressing mode.
+          // The addressing mode has been selected, just add all of the
+          // operands to the machine instruction.
+          for (; NumVals; --NumVals, ++i)
+            AddOperand(MI, Node->getOperand(i), 0, 0, VRBaseMap);
+          break;
+        }
+      }
       break;
     }
     }
   }
 
-  OpSlot = ResultReg;
-  return ResultReg+Op.ResNo;
+  assert(!VRBaseMap.count(Node) && "Node emitted out of order - early");
+  VRBaseMap[Node] = VRBase;
 }
 
-/// Schedule - Order operands according to selected style.
-///
-void SimpleSched::Schedule() {
-  switch (ScheduleStyle) {
-  case simpleScheduling:
-    // Breadth first walk of DAG
-    VisitAll();
-    // Get latency and resource requirements
-    GatherOperandInfo();
-    // Don't waste time if is only entry and return
-    if (Operands.size() > 2) {
-      DEBUG(dump("Pre-"));
-      // Push back long instructions and critical path
-      ScheduleBackward();
-      DEBUG(dump("Mid-"));
-      // Pack instructions to maximize resource utilization
-      ScheduleForward();
-      DEBUG(dump("Post-"));
-      // Emit in scheduled order
-      EmitAll();
-      break;
-    } // fall thru
-  case noScheduling:
-    // Emit instructions in using a DFS from the exit root
-    Emit(DAG.getRoot());
-    break;
-  }
+void ScheduleDAG::EmitNoop() {
+  TII->insertNoop(*BB, BB->end());
 }
 
-/// printSI - Print schedule info.
-///
-void SimpleSched::printSI(std::ostream &O, ScheduleInfo *SI) const {
-#ifndef NDEBUG
-  using namespace std;
-  SDOperand Op = SI->Op;
-  O << " "
-    << hex << Op.Val
-    << ", RS=" << SI->ResourceSet
-    << ", Lat=" << SI->Latency
-    << ", Slot=" << SI->Slot
-    << ", ARITY=(" << Op.getNumOperands() << ","
-                   << Op.Val->getNumValues() << ")"
-    << " " << Op.Val->getOperationName(&DAG);
-  if (isFlagDefiner(Op)) O << "<#";
-  if (isFlagUser(Op)) O << ">#";
-#endif
+/// EmitSchedule - Emit the machine code in scheduled order.
+void ScheduleDAG::EmitSchedule() {
+  std::map<SDNode*, unsigned> VRBaseMap;
+  for (unsigned i = 0, e = Sequence.size(); i != e; i++) {
+    if (SUnit *SU = Sequence[i]) {
+      for (unsigned j = 0, ee = SU->FlaggedNodes.size(); j != ee; j++)
+        EmitNode(SU->FlaggedNodes[j], VRBaseMap);
+      EmitNode(SU->Node, VRBaseMap);
+    } else {
+      // Null SUnit* is a noop.
+      EmitNoop();
+    }
+  }
 }
 
-/// print - Print ordering to specified output stream.
-///
-void SimpleSched::print(std::ostream &O) const {
-#ifndef NDEBUG
-  using namespace std;
-  O << "Ordering\n";
-  for (unsigned i = 0, N = Ordering.size(); i < N; i++) {
-    printSI(O, Ordering[i]);
-    O << "\n";
+/// dump - dump the schedule.
+void ScheduleDAG::dumpSchedule() const {
+  for (unsigned i = 0, e = Sequence.size(); i != e; i++) {
+    if (SUnit *SU = Sequence[i])
+      SU->dump(&DAG);
+    else
+      std::cerr << "**** NOOP ****\n";
   }
-#endif
 }
 
-/// dump - Print ordering to std::cerr.
+
+/// Run - perform scheduling.
 ///
-void SimpleSched::dump() const {
-  print(std::cerr);
+MachineBasicBlock *ScheduleDAG::Run() {
+  TII = TM.getInstrInfo();
+  MRI = TM.getRegisterInfo();
+  RegMap = BB->getParent()->getSSARegMap();
+  ConstPool = BB->getParent()->getConstantPool();
+
+  Schedule();
+  return BB;
 }
-//===----------------------------------------------------------------------===//
 
+/// SUnit - Scheduling unit. It's an wrapper around either a single SDNode or
+/// a group of nodes flagged together.
+void SUnit::dump(const SelectionDAG *G) const {
+  std::cerr << "SU(" << NodeNum << "): ";
+  Node->dump(G);
+  std::cerr << "\n";
+  if (FlaggedNodes.size() != 0) {
+    for (unsigned i = 0, e = FlaggedNodes.size(); i != e; i++) {
+      std::cerr << "    ";
+      FlaggedNodes[i]->dump(G);
+      std::cerr << "\n";
+    }
+  }
+}
 
-//===----------------------------------------------------------------------===//
-/// ScheduleAndEmitDAG - Pick a safe ordering and emit instructions for each
-/// target node in the graph.
-void SelectionDAGISel::ScheduleAndEmitDAG(SelectionDAG &SD) {
-  if (ViewDAGs) SD.viewGraph();
-  BB = SimpleSched(SD, BB).Run();  
+void SUnit::dumpAll(const SelectionDAG *G) const {
+  dump(G);
+
+  std::cerr << "  # preds left       : " << NumPredsLeft << "\n";
+  std::cerr << "  # succs left       : " << NumSuccsLeft << "\n";
+  std::cerr << "  # chain preds left : " << NumChainPredsLeft << "\n";
+  std::cerr << "  # chain succs left : " << NumChainSuccsLeft << "\n";
+  std::cerr << "  Latency            : " << Latency << "\n";
+  std::cerr << "  Depth              : " << Depth << "\n";
+  std::cerr << "  Height             : " << Height << "\n";
+
+  if (Preds.size() != 0) {
+    std::cerr << "  Predecessors:\n";
+    for (std::set<std::pair<SUnit*,bool> >::const_iterator I = Preds.begin(),
+           E = Preds.end(); I != E; ++I) {
+      if (I->second)
+        std::cerr << "   ch  ";
+      else
+        std::cerr << "   val ";
+      I->first->dump(G);
+    }
+  }
+  if (Succs.size() != 0) {
+    std::cerr << "  Successors:\n";
+    for (std::set<std::pair<SUnit*, bool> >::const_iterator I = Succs.begin(),
+           E = Succs.end(); I != E; ++I) {
+      if (I->second)
+        std::cerr << "   ch  ";
+      else
+        std::cerr << "   val ";
+      I->first->dump(G);
+    }
+  }
+  std::cerr << "\n";
 }