Allow redirection of -ddump-* to file
[ghc-hetmet.git] / compiler / main / DriverPipeline.hs
index 800baf1..67fe31d 100644 (file)
@@ -12,16 +12,13 @@ module DriverPipeline (
    oneShot, compileFile,
 
        -- Interfaces for the batch-mode driver
-   staticLink,
+   linkBinary,
 
        -- Interfaces for the compilation manager (interpreted/batch-mode)
    preprocess, 
    compile, CompResult(..), 
    link, 
 
-        -- DLL building
-   doMkDLL,
-
   ) where
 
 #include "HsVersions.h"
@@ -29,8 +26,7 @@ module DriverPipeline (
 import Packages
 import HeaderInfo
 import DriverPhases
-import SysTools                ( newTempName, addFilesToClean, getSysMan, copy )
-import qualified SysTools      
+import SysTools
 import HscMain
 import Finder
 import HscTypes
@@ -39,7 +35,7 @@ import Module
 import UniqFM          ( eltsUFM )
 import ErrUtils
 import DynFlags
-import StaticFlags     ( v_Ld_inputs, opt_Static, WayName(..) )
+import StaticFlags     ( v_Ld_inputs, opt_Static, opt_HardwireLibPaths, WayName(..) )
 import Config
 import Panic
 import Util
@@ -50,17 +46,17 @@ import ParserCoreUtils      ( getCoreModuleName )
 import SrcLoc          ( unLoc )
 import SrcLoc          ( Located(..) )
 
-import EXCEPTION
-import DATA_IOREF      ( readIORef, writeIORef, IORef )
-import GLAEXTS         ( Int(..) )
-
-import Directory
-import System
-import IO
-import Monad
+import Control.Exception as Exception
+import Data.IORef      ( readIORef, writeIORef, IORef )
+import GHC.Exts                ( Int(..) )
+import System.Directory
+import System.IO
+import SYSTEM_IO_ERROR as IO
+import Control.Monad
 import Data.List       ( isSuffixOf )
-import Maybe
-
+import Data.Maybe
+import System.Exit
+import System.Environment
 
 -- ---------------------------------------------------------------------------
 -- Pre-process
@@ -74,7 +70,8 @@ import Maybe
 preprocess :: DynFlags -> (FilePath, Maybe Phase) -> IO (DynFlags, FilePath)
 preprocess dflags (filename, mb_phase) =
   ASSERT2(isJust mb_phase || isHaskellSrcFilename filename, text filename) 
-  runPipeline anyHsc dflags (filename, mb_phase) Temporary Nothing{-no ModLocation-}
+  runPipeline anyHsc dflags (filename, mb_phase) 
+        Nothing Temporary Nothing{-no ModLocation-}
 
 -- ---------------------------------------------------------------------------
 -- Compile
@@ -136,16 +133,16 @@ compile hsc_env mod_summary maybe_old_linkable old_iface mod_index nmods = do
    -- ... and what the next phase should be
    let next_phase = hscNextPhase dflags src_flavour hsc_lang
    -- ... and what file to generate the output into
-   output_fn <- getOutputFilename dflags next_phase 
-                       Temporary basename next_phase (Just location)
+   output_fn <- getOutputFilename next_phase 
+                       Temporary basename dflags next_phase (Just location)
 
    let dflags' = dflags { hscTarget = hsc_lang,
                                hscOutName = output_fn,
                                extCoreName = basename ++ ".hcr" }
 
    -- -no-recomp should also work with --make
-   let do_recomp = dopt Opt_RecompChecking dflags
-       source_unchanged = isJust maybe_old_linkable && do_recomp
+   let force_recomp = dopt Opt_ForceRecomp dflags
+       source_unchanged = isJust maybe_old_linkable && not force_recomp
        hsc_env' = hsc_env { hsc_dflags = dflags' }
        object_filename = ml_obj_file location
 
@@ -159,7 +156,9 @@ compile hsc_env mod_summary maybe_old_linkable old_iface mod_index nmods = do
              return (CompOK details iface maybe_old_linkable)
        handleBatch (HscRecomp hasStub, iface, details)
            | isHsBoot src_flavour
-               = return (CompOK details iface Nothing)
+               = do SysTools.touch dflags' "Touching object file"
+                                   object_filename
+                    return (CompOK details iface Nothing)
            | otherwise
                = do stub_unlinked <- getStubLinkable hasStub
                     (hs_unlinked, unlinked_time) <-
@@ -168,7 +167,9 @@ compile hsc_env mod_summary maybe_old_linkable old_iface mod_index nmods = do
                             -> return ([], ms_hs_date mod_summary)
                           -- We're in --make mode: finish the compilation pipeline.
                           _other
-                            -> do runPipeline StopLn dflags (output_fn,Nothing) Persistent
+                            -> do runPipeline StopLn dflags (output_fn,Nothing)
+                                              (Just basename)
+                                              Persistent
                                               (Just location)
                                   -- The object filename comes from the ModLocation
                                   o_time <- getModificationTime object_filename
@@ -237,7 +238,7 @@ compileStub dflags mod location = do
 
        -- compile the _stub.c file w/ gcc
        let (stub_c,_) = mkStubPaths dflags (moduleName mod) location
-       runPipeline StopLn dflags (stub_c,Nothing) 
+       runPipeline StopLn dflags (stub_c,Nothing)  Nothing
                (SpecificFile stub_o) Nothing{-no ModLocation-}
 
        return stub_o
@@ -246,7 +247,7 @@ compileStub dflags mod location = do
 -- ---------------------------------------------------------------------------
 -- Link
 
-link :: GhcMode                        -- interactive or batch
+link :: GhcLink                        -- interactive or batch
      -> DynFlags               -- dynamic flags
      -> Bool                   -- attempt linking in batch mode?
      -> HomePackageTable       -- what to link
@@ -260,15 +261,15 @@ link :: GhcMode                   -- interactive or batch
 -- will succeed.
 
 #ifdef GHCI
-link Interactive dflags batch_attempt_linking hpt
+link LinkInMemory dflags batch_attempt_linking hpt
     = do -- Not Linking...(demand linker will do the job)
         return Succeeded
 #endif
 
-link JustTypecheck dflags batch_attempt_linking hpt
+link NoLink dflags batch_attempt_linking hpt
    = return Succeeded
 
-link BatchCompile dflags batch_attempt_linking hpt
+link LinkBinary dflags batch_attempt_linking hpt
    | batch_attempt_linking
    = do 
        let 
@@ -302,7 +303,7 @@ link BatchCompile dflags batch_attempt_linking hpt
                | Right t <- e_exe_time = 
                        any (t <) (map linkableTime linkables)
 
-       if dopt Opt_RecompChecking dflags && not linking_needed
+       if not (dopt Opt_ForceRecomp dflags) && not linking_needed
           then do debugTraceMsg dflags 2 (text exe_file <+> ptext SLIT("is up to date, linking not required."))
                   return Succeeded
           else do
@@ -312,13 +313,13 @@ link BatchCompile dflags batch_attempt_linking hpt
 
        -- Don't showPass in Batch mode; doLink will do that for us.
        let link = case ghcLink dflags of
-               MkDLL       -> doMkDLL
-               StaticLink  -> staticLink
+               LinkBinary  -> linkBinary
+               LinkDynLib  -> linkDynLib
        link dflags obj_files pkg_deps
 
         debugTraceMsg dflags 3 (text "link: done")
 
-       -- staticLink only returns if it succeeds
+       -- linkBinary only returns if it succeeds
         return Succeeded
 
    | otherwise
@@ -326,7 +327,6 @@ link BatchCompile dflags batch_attempt_linking hpt
                                 text "   Main.main not exported; not linking.")
         return Succeeded
       
-
 -- -----------------------------------------------------------------------------
 -- Compile files in one-shot mode.
 
@@ -360,7 +360,8 @@ compileFile dflags stop_phase (src, mb_phase) = do
                        other      -> stop_phase
 
    (_, out_file) <- runPipeline stop_phase' dflags
-                         (src, mb_phase) output Nothing{-no ModLocation-}
+                         (src, mb_phase) Nothing output 
+                          Nothing{-no ModLocation-}
    return out_file
 
 
@@ -372,8 +373,8 @@ doLink dflags stop_phase o_files
   | otherwise
   = case ghcLink dflags of
        NoLink     -> return ()
-       StaticLink -> staticLink dflags o_files link_pkgs
-       MkDLL      -> doMkDLL dflags o_files link_pkgs
+       LinkBinary -> linkBinary dflags o_files link_pkgs
+       LinkDynLib -> linkDynLib dflags o_files []
   where
    -- Always link in the haskell98 package for static linking.  Other
    -- packages have to be specified via the -package flag.
@@ -406,18 +407,23 @@ runPipeline
   :: Phase                     -- When to stop
   -> DynFlags                  -- Dynamic flags
   -> (FilePath,Maybe Phase)     -- Input filename (and maybe -x suffix)
+  -> Maybe FilePath             -- original basename (if different from ^^^)
   -> PipelineOutput            -- Output filename
   -> Maybe ModLocation          -- A ModLocation, if this is a Haskell module
   -> IO (DynFlags, FilePath)   -- (final flags, output filename)
 
-runPipeline stop_phase dflags (input_fn, mb_phase) output maybe_loc
+runPipeline stop_phase dflags0 (input_fn, mb_phase) mb_basename output maybe_loc
   = do
-  let (basename, suffix) = splitFilename input_fn
+  let
+      (input_basename, suffix) = splitFilename input_fn
+      basename | Just b <- mb_basename = b
+               | otherwise             = input_basename
+
+      -- Decide where dump files should go based on the pipeline output
+      dflags = dflags0 { dumpPrefix = Just (basename ++ ".") }
 
        -- If we were given a -x flag, then use that phase to start from
-      start_phase
-       | Just x_phase <- mb_phase = x_phase
-       | otherwise                = startPhase suffix
+      start_phase = fromMaybe (startPhase suffix) mb_phase
 
   -- We want to catch cases of "you can't get there from here" before
   -- we start the pipeline, because otherwise it will just run off the
@@ -433,7 +439,7 @@ runPipeline stop_phase dflags (input_fn, mb_phase) output maybe_loc
 
   -- this is a function which will be used to calculate output file names
   -- as we go along (we partially apply it to some of its inputs here)
-  let get_output_fn = getOutputFilename dflags stop_phase output basename
+  let get_output_fn = getOutputFilename stop_phase output basename
 
   -- Execute the pipeline...
   (dflags', output_fn, maybe_loc) <- 
@@ -443,22 +449,24 @@ runPipeline stop_phase dflags (input_fn, mb_phase) output maybe_loc
   -- Sometimes, a compilation phase doesn't actually generate any output
   -- (eg. the CPP phase when -fcpp is not turned on).  If we end on this
   -- stage, but we wanted to keep the output, then we have to explicitly
-  -- copy the file.
+  -- copy the file, remembering to prepend a {-# LINE #-} pragma so that
+  -- further compilation stages can tell what the original filename was.
   case output of
     Temporary -> 
        return (dflags', output_fn)
     _other ->
-       do final_fn <- get_output_fn stop_phase maybe_loc
-          when (final_fn /= output_fn) $
-                 copy dflags ("Copying `" ++ output_fn ++ "' to `" ++ final_fn
-                       ++ "'") output_fn final_fn
+       do final_fn <- get_output_fn dflags' stop_phase maybe_loc
+          when (final_fn /= output_fn) $ do
+              let msg = ("Copying `" ++ output_fn ++"' to `" ++ final_fn ++ "'")
+                  line_prag = Just ("{-# LINE 1 \"" ++ input_fn ++ "\" #-}\n")
+             copyWithHeader dflags msg line_prag output_fn final_fn
           return (dflags', final_fn)
-               
+
 
 
 pipeLoop :: DynFlags -> Phase -> Phase 
         -> FilePath  -> String -> Suffix
-        -> (Phase -> Maybe ModLocation -> IO FilePath)
+        -> (DynFlags -> Phase -> Maybe ModLocation -> IO FilePath)
         -> Maybe ModLocation
         -> IO (DynFlags, FilePath, Maybe ModLocation)
 
@@ -485,28 +493,28 @@ pipeLoop dflags phase stop_phase
                   orig_basename orig_suff orig_get_output_fn maybe_loc }
 
 getOutputFilename
-  :: DynFlags -> Phase -> PipelineOutput -> String
-  -> Phase{-next phase-} -> Maybe ModLocation -> IO FilePath
-getOutputFilename dflags stop_phase output basename
+  :: Phase -> PipelineOutput -> String
+  -> DynFlags -> Phase{-next phase-} -> Maybe ModLocation -> IO FilePath
+getOutputFilename stop_phase output basename
  = func
  where
-       hcsuf      = hcSuf dflags
-       odir       = objectDir dflags
-       osuf       = objectSuf dflags
-       keep_hc    = dopt Opt_KeepHcFiles dflags
-       keep_raw_s = dopt Opt_KeepRawSFiles dflags
-       keep_s     = dopt Opt_KeepSFiles dflags
-
-        myPhaseInputExt HCc    = hcsuf
-        myPhaseInputExt StopLn = osuf
-        myPhaseInputExt other  = phaseInputExt other
-
-       func next_phase maybe_location
+       func dflags next_phase maybe_location
           | is_last_phase, Persistent <- output     = persistent_fn
           | is_last_phase, SpecificFile f <- output = return f
           | keep_this_output                        = persistent_fn
           | otherwise                               = newTempName dflags suffix
           where
+               hcsuf      = hcSuf dflags
+               odir       = objectDir dflags
+               osuf       = objectSuf dflags
+               keep_hc    = dopt Opt_KeepHcFiles dflags
+               keep_raw_s = dopt Opt_KeepRawSFiles dflags
+               keep_s     = dopt Opt_KeepSFiles dflags
+
+               myPhaseInputExt HCc    = hcsuf
+               myPhaseInputExt StopLn = osuf
+               myPhaseInputExt other  = phaseInputExt other
+
                is_last_phase = next_phase `eqPhase` stop_phase
 
                -- sometimes, we keep output from intermediate stages
@@ -549,7 +557,7 @@ runPhase :: Phase   -- Do this phase first
         -> String      -- basename of original input source
         -> String      -- its extension
         -> FilePath    -- name of file which contains the input to this phase.
-        -> (Phase -> Maybe ModLocation -> IO FilePath)
+        -> (DynFlags -> Phase -> Maybe ModLocation -> IO FilePath)
                        -- how to calculate the output filename
         -> Maybe ModLocation           -- the ModLocation, if we have one
         -> IO (Phase,                  -- next phase
@@ -567,7 +575,7 @@ runPhase :: Phase   -- Do this phase first
 runPhase (Unlit sf) _stop dflags _basename _suff input_fn get_output_fn maybe_loc
   = do let unlit_flags = getOpts dflags opt_L
        -- The -h option passes the file name for unlit to put in a #line directive
-       output_fn <- get_output_fn (Cpp sf) maybe_loc
+       output_fn <- get_output_fn dflags (Cpp sf) maybe_loc
 
        SysTools.runUnlit dflags 
                (map SysTools.Option unlit_flags ++
@@ -593,7 +601,7 @@ runPhase (Cpp sf) _stop dflags0 basename suff input_fn get_output_fn maybe_loc
           -- to the next phase of the pipeline.
           return (HsPp sf, dflags, maybe_loc, input_fn)
        else do
-           output_fn <- get_output_fn (HsPp sf) maybe_loc
+           output_fn <- get_output_fn dflags (HsPp sf) maybe_loc
            doCpp dflags True{-raw-} False{-no CC opts-} input_fn output_fn
            return (HsPp sf, dflags, maybe_loc, output_fn)
 
@@ -608,7 +616,7 @@ runPhase (HsPp sf) _stop dflags basename suff input_fn get_output_fn maybe_loc
        else do
            let hspp_opts = getOpts dflags opt_F
            let orig_fn = basename `joinFileExt` suff
-           output_fn <- get_output_fn (Hsc sf) maybe_loc
+           output_fn <- get_output_fn dflags (Hsc sf) maybe_loc
            SysTools.runPp dflags
                           ( [ SysTools.Option     orig_fn
                             , SysTools.Option     input_fn
@@ -635,15 +643,15 @@ runPhase (Hsc src_flavour) stop dflags0 basename suff input_fn get_output_fn _ma
            dflags = dflags0 { includePaths = current_dir : paths }
        
   -- gather the imports and module name
-        (hspp_buf,mod_name) <- 
+        (hspp_buf,mod_name,imps,src_imps) <- 
             case src_flavour of
                ExtCoreFile -> do {  -- no explicit imports in ExtCore input.
                                  ; m <- getCoreModuleName input_fn
-                                 ; return (Nothing, mkModuleName m) }
+                                 ; return (Nothing, mkModuleName m, [], []) }
 
                other -> do { buf <- hGetStringBuffer input_fn
-                           ; (_,_,L _ mod_name) <- getImports dflags buf input_fn
-                           ; return (Just buf, mod_name) }
+                           ; (src_imps,imps,L _ mod_name) <- getImports dflags buf input_fn
+                           ; return (Just buf, mod_name, imps, src_imps) }
 
   -- Build a ModLocation to pass to hscMain.
   -- The source filename is rather irrelevant by now, but it's used
@@ -688,9 +696,9 @@ runPhase (Hsc src_flavour) stop dflags0 basename suff input_fn get_output_fn _ma
   -- date wrt M.hs (or M.o doesn't exist) so we must recompile regardless.
        src_timestamp <- getModificationTime (basename `joinFileExt` suff)
 
-       let do_recomp = dopt Opt_RecompChecking dflags
+       let force_recomp = dopt Opt_ForceRecomp dflags
        source_unchanged <- 
-          if not do_recomp || not (isStopLn stop)
+          if force_recomp || not (isStopLn stop)
                -- Set source_unchanged to False unconditionally if
                --      (a) recompilation checker is off, or
                --      (b) we aren't going all the way to .o file (e.g. ghc -S)
@@ -707,7 +715,7 @@ runPhase (Hsc src_flavour) stop dflags0 basename suff input_fn get_output_fn _ma
   -- get the DynFlags
        let hsc_lang = hscMaybeAdjustTarget dflags stop src_flavour (hscTarget dflags)
        let next_phase = hscNextPhase dflags src_flavour hsc_lang
-       output_fn  <- get_output_fn next_phase (Just location4)
+       output_fn  <- get_output_fn dflags next_phase (Just location4)
 
         let dflags' = dflags { hscTarget = hsc_lang,
                               hscOutName = output_fn,
@@ -730,8 +738,8 @@ runPhase (Hsc src_flavour) stop dflags0 basename suff input_fn get_output_fn _ma
                                        ms_location  = location4,
                                        ms_hs_date   = src_timestamp,
                                        ms_obj_date  = Nothing,
-                                       ms_imps      = unused_field,
-                                       ms_srcimps   = unused_field }
+                                       ms_imps      = imps,
+                                       ms_srcimps   = src_imps }
 
   -- run the compiler!
        mbResult <- hscCompileOneShot hsc_env
@@ -762,7 +770,7 @@ runPhase (Hsc src_flavour) stop dflags0 basename suff input_fn get_output_fn _ma
 
 runPhase CmmCpp stop dflags basename suff input_fn get_output_fn maybe_loc
   = do
-       output_fn <- get_output_fn Cmm maybe_loc
+       output_fn <- get_output_fn dflags Cmm maybe_loc
        doCpp dflags False{-not raw-} True{-include CC opts-} input_fn output_fn        
        return (Cmm, dflags, maybe_loc, output_fn)
 
@@ -770,7 +778,7 @@ runPhase Cmm stop dflags basename suff input_fn get_output_fn maybe_loc
   = do
        let hsc_lang = hscMaybeAdjustTarget dflags stop HsSrcFile (hscTarget dflags)
        let next_phase = hscNextPhase dflags HsSrcFile hsc_lang
-       output_fn <- get_output_fn next_phase maybe_loc
+       output_fn <- get_output_fn dflags next_phase maybe_loc
 
         let dflags' = dflags { hscTarget = hsc_lang,
                               hscOutName = output_fn,
@@ -789,7 +797,7 @@ runPhase Cmm stop dflags basename suff input_fn get_output_fn maybe_loc
 -- way too many hacks, and I can't say I've ever used it anyway.
 
 runPhase cc_phase stop dflags basename suff input_fn get_output_fn maybe_loc
-   | cc_phase `eqPhase` Cc || cc_phase `eqPhase` HCc
+   | cc_phase `eqPhase` Cc || cc_phase `eqPhase` Ccpp || cc_phase `eqPhase` HCc
    = do        let cc_opts = getOpts dflags opt_c
            hcc = cc_phase `eqPhase` HCc
 
@@ -806,6 +814,7 @@ runPhase cc_phase stop dflags basename suff input_fn get_output_fn maybe_loc
                              (cmdline_include_paths ++ pkg_include_dirs)
 
        let (md_c_flags, md_regd_c_flags) = machdepCCOpts dflags
+        gcc_extra_viac_flags <- getExtraViaCOpts dflags
         let pic_c_flags = picCCOpts dflags
 
         let verb = getVerbFlag dflags
@@ -827,7 +836,7 @@ runPhase cc_phase stop dflags basename suff input_fn get_output_fn maybe_loc
             next_phase
                | hcc && mangle     = Mangle
                | otherwise         = As
-       output_fn <- get_output_fn next_phase maybe_loc
+       output_fn <- get_output_fn dflags next_phase maybe_loc
 
        let
          more_hcc_opts =
@@ -851,7 +860,8 @@ runPhase cc_phase stop dflags basename suff input_fn get_output_fn maybe_loc
                -- compiling .hc files, by adding the -x c option.
                -- Also useful for plain .c files, just in case GHC saw a 
                -- -x c option.
-                       [ SysTools.Option "-x", SysTools.Option "c"] ++
+                       [ SysTools.Option "-x", if cc_phase `eqPhase` Ccpp
+                                                then SysTools.Option "c++" else SysTools.Option "c"] ++
                        [ SysTools.FileOption "" input_fn
                        , SysTools.Option "-o"
                        , SysTools.FileOption "" output_fn
@@ -859,9 +869,25 @@ runPhase cc_phase stop dflags basename suff input_fn get_output_fn maybe_loc
                       ++ map SysTools.Option (
                          md_c_flags
                        ++ pic_c_flags
+#ifdef sparc_TARGET_ARCH
+        -- We only support SparcV9 and better because V8 lacks an atomic CAS
+        -- instruction. Note that the user can still override this
+       -- (e.g., -mcpu=ultrasparc) as GCC picks the "best" -mcpu flag
+       -- regardless of the ordering.
+        --
+        -- This is a temporary hack.
+                       ++ ["-mcpu=v9"]
+#endif
                       ++ (if hcc && mangle
                             then md_regd_c_flags
                             else [])
+                      ++ (if hcc
+                            then if mangle 
+                                     then gcc_extra_viac_flags
+                                     else filter (=="-fwrapv")
+                                                gcc_extra_viac_flags
+                                -- still want -fwrapv even for unreg'd
+                            else [])
                       ++ (if hcc 
                             then more_hcc_opts
                             else [])
@@ -893,7 +919,7 @@ runPhase Mangle stop dflags _basename _suff input_fn get_output_fn maybe_loc
             next_phase
                | split = SplitMangle
                | otherwise = As
-       output_fn <- get_output_fn next_phase maybe_loc
+       output_fn <- get_output_fn dflags next_phase maybe_loc
 
        SysTools.runMangle dflags (map SysTools.Option mangler_opts
                          ++ [ SysTools.FileOption "" input_fn
@@ -937,7 +963,7 @@ runPhase As stop dflags _basename _suff input_fn get_output_fn maybe_loc
   = do let as_opts =  getOpts dflags opt_a
         let cmdline_include_paths = includePaths dflags
 
-       output_fn <- get_output_fn StopLn maybe_loc
+       output_fn <- get_output_fn dflags StopLn maybe_loc
 
        -- we create directories for the object file, because it
        -- might be a hierarchical module.
@@ -946,6 +972,16 @@ runPhase As stop dflags _basename _suff input_fn get_output_fn maybe_loc
        SysTools.runAs dflags   
                       (map SysTools.Option as_opts
                       ++ [ SysTools.Option ("-I" ++ p) | p <- cmdline_include_paths ]
+#ifdef sparc_TARGET_ARCH
+        -- We only support SparcV9 and better because V8 lacks an atomic CAS
+       -- instruction so we have to make sure that the assembler accepts the
+        -- instruction set. Note that the user can still override this
+       -- (e.g., -mcpu=ultrasparc). GCC picks the "best" -mcpu flag
+       -- regardless of the ordering.
+       --
+       -- This is a temporary hack.
+                      ++ [ SysTools.Option "-mcpu=v9" ]
+#endif
                       ++ [ SysTools.Option "-c"
                          , SysTools.FileOption "" input_fn
                          , SysTools.Option "-o"
@@ -957,7 +993,7 @@ runPhase As stop dflags _basename _suff input_fn get_output_fn maybe_loc
 
 runPhase SplitAs stop dflags basename _suff _input_fn get_output_fn maybe_loc
   = do  
-       output_fn <- get_output_fn StopLn maybe_loc
+       output_fn <- get_output_fn dflags StopLn maybe_loc
 
        let (base_o, _) = splitFilename output_fn
            split_odir  = base_o ++ "_split"
@@ -1020,23 +1056,23 @@ runPhase SplitAs stop dflags basename _suff _input_fn get_output_fn maybe_loc
 -- wrapper script calling the binary. Currently, we need this only in 
 -- a parallel way (i.e. in GUM), because PVM expects the binary in a
 -- central directory.
--- This is called from staticLink below, after linking. I haven't made it
+-- This is called from linkBinary below, after linking. I haven't made it
 -- a separate phase to minimise interfering with other modules, and
 -- we don't need the generality of a phase (MoveBinary is always
 -- done after linking and makes only sense in a parallel setup)   -- HWL
 
-runPhase_MoveBinary input_fn
+runPhase_MoveBinary dflags input_fn
   = do 
-        sysMan   <- getSysMan
+        let sysMan = pgm_sysman dflags
         pvm_root <- getEnv "PVM_ROOT"
         pvm_arch <- getEnv "PVM_ARCH"
         let 
            pvm_executable_base = "=" ++ input_fn
            pvm_executable = pvm_root ++ "/bin/" ++ pvm_arch ++ "/" ++ pvm_executable_base
         -- nuke old binary; maybe use configur'ed names for cp and rm?
-        system ("rm -f " ++ pvm_executable)
+        Panic.try (removeFile pvm_executable)
         -- move the newly created binary into PVM land
-        system ("cp -p " ++ input_fn ++ " " ++ pvm_executable)
+        copy dflags "copying PVM executable" input_fn pvm_executable
         -- generate a wrapper script for running a parallel prg under PVM
         writeFile input_fn (mk_pvm_wrapper_script pvm_executable pvm_executable_base sysMan)
        return True
@@ -1074,18 +1110,18 @@ mk_pvm_wrapper_script pvm_executable pvm_executable_base sysMan = unlines $
   "",
   "args: while ($a = shift(@ARGV)) {",
   "    if ( $a eq '+RTS' ) {",
-  "    $in_RTS_args = 1;",
+  "        $in_RTS_args = 1;",
   "    } elsif ( $a eq '-RTS' ) {",
-  "    $in_RTS_args = 0;",
+  "        $in_RTS_args = 0;",
   "    }",
   "    if ( $a eq '-d' && $in_RTS_args ) {",
-  "    $debug = '-';",
+  "        $debug = '-';",
   "    } elsif ( $a =~ /^-qN(\\d+)/ && $in_RTS_args ) {",
-  "    $nprocessors = $1;",
+  "        $nprocessors = $1;",
   "    } elsif ( $a =~ /^-qp(\\d+)/ && $in_RTS_args ) {",
-  "    $nprocessors = $1;",
+  "        $nprocessors = $1;",
   "    } else {",
-  "    push(@nonPVM_args, $a);",
+  "        push(@nonPVM_args, $a);",
   "    }",
   "}",
   "",
@@ -1113,7 +1149,7 @@ checkProcessArgsResult flags filename
 
 getHCFilePackages :: FilePath -> IO [PackageId]
 getHCFilePackages filename =
-  EXCEPTION.bracket (openFile filename ReadMode) hClose $ \h -> do
+  Exception.bracket (openFile filename ReadMode) hClose $ \h -> do
     l <- hGetLine h
     case l of
       '/':'*':' ':'G':'H':'C':'_':'P':'A':'C':'K':'A':'G':'E':'S':rest ->
@@ -1134,8 +1170,8 @@ getHCFilePackages filename =
 -- read any interface files), so the user must explicitly specify all
 -- the packages.
 
-staticLink :: DynFlags -> [FilePath] -> [PackageId] -> IO ()
-staticLink dflags o_files dep_packages = do
+linkBinary :: DynFlags -> [FilePath] -> [PackageId] -> IO ()
+linkBinary dflags o_files dep_packages = do
     let verb = getVerbFlag dflags
         output_fn = exeFileName dflags
 
@@ -1144,7 +1180,9 @@ staticLink dflags o_files dep_packages = do
     -- dependencies, and eliminating duplicates.
 
     pkg_lib_paths <- getPackageLibraryPath dflags dep_packages
-    let pkg_lib_path_opts = map ("-L"++) pkg_lib_paths
+    let pkg_lib_path_opts = concat (map get_pkg_lib_path_opts pkg_lib_paths)
+       get_pkg_lib_path_opts l | opt_HardwireLibPaths && not opt_Static = ["-L" ++ l, "-Wl,-rpath", "-Wl," ++ l]
+                               | otherwise = ["-L" ++ l]
 
     let lib_paths = libraryPaths dflags
     let lib_path_opts = map ("-L"++) lib_paths
@@ -1196,6 +1234,8 @@ staticLink dflags o_files dep_packages = do
                        ]
                    | otherwise               = []
 
+    rc_objs <- maybeCreateManifest dflags output_fn
+
     let (md_c_flags, _) = machdepCCOpts dflags
     SysTools.runLink dflags ( 
                       [ SysTools.Option verb
@@ -1208,6 +1248,7 @@ staticLink dflags o_files dep_packages = do
                      ++ extra_ld_inputs
                      ++ lib_path_opts
                      ++ extra_ld_opts
+                      ++ rc_objs
 #ifdef darwin_TARGET_OS
                      ++ framework_path_opts
                      ++ framework_opts
@@ -1224,7 +1265,7 @@ staticLink dflags o_files dep_packages = do
 
     -- parallel only: move binary to another dir -- HWL
     when (WayPar `elem` ways)
-        (do success <- runPhase_MoveBinary output_fn
+        (do success <- runPhase_MoveBinary dflags output_fn
              if success then return ()
                         else throwDyn (InstallationError ("cannot move binary to PVM dir")))
 
@@ -1246,16 +1287,65 @@ exeFileName dflags
        "a.out"
 #endif
 
------------------------------------------------------------------------------
--- Making a DLL (only for Win32)
+maybeCreateManifest
+   :: DynFlags
+   -> FilePath                          -- filename of executable
+   -> IO [FilePath]                     -- extra objects to embed, maybe
+maybeCreateManifest dflags exe_filename = do
+#ifndef mingw32_TARGET_OS
+  return []
+#else
+  if not (dopt Opt_GenManifest dflags) then return [] else do
+
+  let manifest_filename = exe_filename `joinFileExt` "manifest"
+
+  writeFile manifest_filename $ 
+      "<?xml version=\"1.0\" encoding=\"UTF-8\" standalone=\"yes\"?>\n"++
+      "  <assembly xmlns=\"urn:schemas-microsoft-com:asm.v1\" manifestVersion=\"1.0\">\n"++
+      "  <assemblyIdentity version=\"1.0.0.0\"\n"++
+      "     processorArchitecture=\"X86\"\n"++
+      "     name=\"" ++ basenameOf exe_filename ++ "\"\n"++
+      "     type=\"win32\"/>\n\n"++
+      "  <trustInfo xmlns=\"urn:schemas-microsoft-com:asm.v3\">\n"++
+      "    <security>\n"++
+      "      <requestedPrivileges>\n"++
+      "        <requestedExecutionLevel level=\"asInvoker\" uiAccess=\"false\"/>\n"++
+      "        </requestedPrivileges>\n"++
+      "       </security>\n"++
+      "  </trustInfo>\n"++
+      "</assembly>\n"
+
+  -- Windows will fine the manifest file if it is named foo.exe.manifest.
+  -- However, for extra robustness, and so that we can move the binary around,
+  -- we can embed the manifest in the binary itself using windres:
+  if not (dopt Opt_EmbedManifest dflags) then return [] else do
+
+  rc_filename <- newTempName dflags "rc"
+  rc_obj_filename <- newTempName dflags (objectSuf dflags)
+
+  writeFile rc_filename $
+      "1 24 MOVEABLE PURE \"" ++ manifest_filename ++ "\"\n"
+        -- magic numbers :-)
+
+  let wr_opts = getOpts dflags opt_windres
+  runWindres dflags $ map SysTools.Option $
+        ["--input="++rc_filename, 
+         "--output="++rc_obj_filename,
+         "--output-format=coff"] 
+        ++ wr_opts
+        -- no FileOptions here: windres doesn't like seeing
+        -- backslashes, apparently
+
+  return [rc_obj_filename]
+#endif
+
 
-doMkDLL :: DynFlags -> [String] -> [PackageId] -> IO ()
-doMkDLL dflags o_files dep_packages = do
+linkDynLib :: DynFlags -> [String] -> [PackageId] -> IO ()
+linkDynLib dflags o_files dep_packages = do
     let verb = getVerbFlag dflags
     let static = opt_Static
     let no_hs_main = dopt Opt_NoHsMain dflags
     let o_file = outputFile dflags
-    let output_fn = case o_file of { Just s -> s; Nothing -> "HSdll.dll"; }
 
     pkg_lib_paths <- getPackageLibraryPath dflags dep_packages
     let pkg_lib_path_opts = map ("-L"++) pkg_lib_paths
@@ -1268,20 +1358,89 @@ doMkDLL dflags o_files dep_packages = do
        -- probably _stub.o files
     extra_ld_inputs <- readIORef v_Ld_inputs
 
-       -- opts from -optdll-<blah>
-    let extra_ld_opts = getOpts dflags opt_dll 
+    let (md_c_flags, _) = machdepCCOpts dflags
+    let extra_ld_opts = getOpts dflags opt_l
+#if defined(mingw32_HOST_OS)
+    -----------------------------------------------------------------------------
+    -- Making a DLL
+    -----------------------------------------------------------------------------
+    let output_fn = case o_file of { Just s -> s; Nothing -> "HSdll.dll"; }
 
-    let pstate = pkgState dflags
-       rts_pkg  = getPackageDetails pstate rtsPackageId
-        base_pkg = getPackageDetails pstate basePackageId
+    SysTools.runLink dflags
+        ([ SysTools.Option verb
+         , SysTools.Option "-o"
+         , SysTools.FileOption "" output_fn
+         , SysTools.Option "-shared"
+         , SysTools.Option "-Wl,--export-all-symbols"
+         , SysTools.FileOption "-Wl,--out-implib=" (output_fn ++ ".a")
+         ]
+        ++ map (SysTools.FileOption "") o_files
+        ++ map SysTools.Option (
+           md_c_flags
+        ++ extra_ld_inputs
+        ++ lib_path_opts
+        ++ extra_ld_opts
+        ++ pkg_lib_path_opts
+        ++ pkg_link_opts
+       ))
+#elif defined(darwin_TARGET_OS)
+    -----------------------------------------------------------------------------
+    -- Making a darwin dylib
+    -----------------------------------------------------------------------------
+    -- About the options used for Darwin:
+    -- -dynamiclib
+    --   Apple's way of saying -shared
+    -- -undefined dynamic_lookup:
+    --   Without these options, we'd have to specify the correct dependencies
+    --   for each of the dylibs. Note that we could (and should) do without this
+    --  for all libraries except the RTS; all we need to do is to pass the
+    --  correct HSfoo_dyn.dylib files to the link command.
+    --  This feature requires Mac OS X 10.3 or later; there is a similar feature,
+    --  -flat_namespace -undefined suppress, which works on earlier versions,
+    --  but it has other disadvantages.
+    -- -single_module
+    --  Build the dynamic library as a single "module", i.e. no dynamic binding
+    --  nonsense when referring to symbols from within the library. The NCG
+    --  assumes that this option is specified (on i386, at least).
+    -- -Wl,-macosx_version_min -Wl,10.3
+    --  Tell the linker its safe to assume that the library will run on 10.3 or
+    --  later, so that it will not complain about the use of the option
+    --  -undefined dynamic_lookup above.
+    -- -install_name
+    --   Causes the dynamic linker to ignore the DYLD_LIBRARY_PATH when loading
+    --   this lib and instead look for it at its absolute path.
+    --   When installing the .dylibs (see target.mk), we'll change that path to
+    --   point to the place they are installed. Therefore, we won't have to set
+    --  up DYLD_LIBRARY_PATH specifically for ghc.
+    -----------------------------------------------------------------------------
+
+    let output_fn = case o_file of { Just s -> s; Nothing -> "a.out"; }
+
+    pwd <- getCurrentDirectory
+    SysTools.runLink dflags
+        ([ SysTools.Option verb
+         , SysTools.Option "-dynamiclib"
+         , SysTools.Option "-o"
+         , SysTools.FileOption "" output_fn
+         ]
+        ++ map SysTools.Option (
+           md_c_flags
+        ++ o_files
+        ++ [ "-undefined", "dynamic_lookup", "-single_module", "-Wl,-macosx_version_min","-Wl,10.3", "-install_name " ++ (pwd `joinFileName` output_fn) ]
+        ++ extra_ld_inputs
+        ++ lib_path_opts
+        ++ extra_ld_opts
+        ++ pkg_lib_path_opts
+        ++ pkg_link_opts
+       ))
+#else
+    -----------------------------------------------------------------------------
+    -- Making a DSO
+    -----------------------------------------------------------------------------
 
-    let extra_os = if static || no_hs_main
-                   then []
-                   else [ head (libraryDirs rts_pkg) ++ "/Main.dll_o",
-                          head (libraryDirs base_pkg) ++ "/PrelMain.dll_o" ]
+    let output_fn = case o_file of { Just s -> s; Nothing -> "a.out"; }
 
-    let (md_c_flags, _) = machdepCCOpts dflags
-    SysTools.runMkDLL dflags
+    SysTools.runLink dflags
         ([ SysTools.Option verb
          , SysTools.Option "-o"
          , SysTools.FileOption "" output_fn
@@ -1289,18 +1448,14 @@ doMkDLL dflags o_files dep_packages = do
         ++ map SysTools.Option (
            md_c_flags
         ++ o_files
-        ++ extra_os
-        ++ [ "--target=i386-mingw32" ]
+        ++ [ "-shared", "-Wl,-Bsymbolic" ] -- we need symbolic linking to resolve non-PIC intra-package-relocations
         ++ extra_ld_inputs
         ++ lib_path_opts
         ++ extra_ld_opts
         ++ pkg_lib_path_opts
         ++ pkg_link_opts
-         ++ (if "--def" `elem` (concatMap words extra_ld_opts)
-              then [ "" ]
-               else [ "--export-all" ])
        ))
-
+#endif
 -- -----------------------------------------------------------------------------
 -- Running CPP
 
@@ -1381,8 +1536,6 @@ hscNextPhase dflags other hsc_lang =
 
 
 hscMaybeAdjustTarget :: DynFlags -> Phase -> HscSource -> HscTarget -> HscTarget
-hscMaybeAdjustTarget dflags stop HsBootFile current_hsc_lang 
-  = HscNothing         -- No output (other than Foo.hi-boot) for hs-boot files
 hscMaybeAdjustTarget dflags stop other current_hsc_lang 
   = hsc_lang 
   where