Be more tolerant to missing values or errors in io_config()
[ardour.git] / libs / ardour / midi_diskstream.cc
index 48fd3fb77fad47d4bbd61dab88f320a92d5b9753..4d3dd4e5a7784c31cd97ec38671da2efd6ff7a14 100644 (file)
@@ -16,7 +16,6 @@
     Foundation, Inc., 675 Mass Ave, Cambridge, MA 02139, USA.
 */
 
-#include <fstream>
 #include <cstdio>
 #include <unistd.h>
 #include <cmath>
@@ -27,9 +26,9 @@
 #include <cstdlib>
 #include <ctime>
 #include <sys/stat.h>
-#include <sys/mman.h>
 
 #include "pbd/error.h"
+#include "pbd/ffs.h"
 #include "pbd/basename.h"
 #include <glibmm/threads.h>
 #include "pbd/xml++.h"
@@ -47,6 +46,8 @@
 #include "ardour/midi_playlist.h"
 #include "ardour/midi_port.h"
 #include "ardour/midi_region.h"
+#include "ardour/midi_ring_buffer.h"
+#include "ardour/midi_track.h"
 #include "ardour/playlist_factory.h"
 #include "ardour/region_factory.h"
 #include "ardour/session.h"
@@ -57,7 +58,7 @@
 
 #include "midi++/types.h"
 
-#include "i18n.h"
+#include "pbd/i18n.h"
 #include <locale.h>
 
 using namespace std;
@@ -74,6 +75,8 @@ MidiDiskstream::MidiDiskstream (Session &sess, const string &name, Diskstream::F
        , _frames_written_to_ringbuffer(0)
        , _frames_read_from_ringbuffer(0)
        , _frames_pending_write(0)
+       , _num_captured_loops(0)
+       , _accumulated_capture_offset(0)
        , _gui_feed_buffer(AudioEngine::instance()->raw_buffer_size (DataType::MIDI))
 {
        in_set_state = true;
@@ -97,6 +100,8 @@ MidiDiskstream::MidiDiskstream (Session& sess, const XMLNode& node)
        , _frames_written_to_ringbuffer(0)
        , _frames_read_from_ringbuffer(0)
        , _frames_pending_write(0)
+       , _num_captured_loops(0)
+       , _accumulated_capture_offset(0)
        , _gui_feed_buffer(AudioEngine::instance()->raw_buffer_size (DataType::MIDI))
 {
        in_set_state = true;
@@ -129,11 +134,14 @@ MidiDiskstream::init ()
        _capture_buf = new MidiRingBuffer<framepos_t>(size);
 
        _n_channels = ChanCount(DataType::MIDI, 1);
+       interpolation.add_channel_to (0,0);
 }
 
 MidiDiskstream::~MidiDiskstream ()
 {
        Glib::Threads::Mutex::Lock lm (state_lock);
+       delete _playback_buf;
+       delete _capture_buf;
 }
 
 
@@ -199,10 +207,8 @@ MidiDiskstream::non_realtime_input_change ()
                seek (_session.transport_frame());
        }
 
-       g_atomic_int_set(&_frames_pending_write, 0);
-       if (_write_source) {
-               _write_source->set_last_write_end (_session.transport_frame());
-       }
+       g_atomic_int_set(const_cast<gint*> (&_frames_pending_write), 0);
+       g_atomic_int_set(const_cast<gint*> (&_num_captured_loops), 0);
 }
 
 int
@@ -299,8 +305,28 @@ MidiDiskstream::set_note_mode (NoteMode m)
                _write_source->model()->set_note_mode(m);
 }
 
+/** Get the start, end, and length of a location "atomically".
+ *
+ * Note: Locations don't get deleted, so all we care about when I say "atomic"
+ * is that we are always pointing to the same one and using start/length values
+ * obtained just once.  Use this function to achieve this since location being
+ * a parameter achieves this.
+ */
+static void
+get_location_times(const Location* location,
+                   framepos_t*     start,
+                   framepos_t*     end,
+                   framepos_t*     length)
+{
+       if (location) {
+               *start  = location->start();
+               *end    = location->end();
+               *length = *end - *start;
+       }
+}
+
 int
-MidiDiskstream::process (framepos_t transport_frame, pframes_t nframes, framecnt_t& playback_distance)
+MidiDiskstream::process (BufferSet& bufs, framepos_t transport_frame, pframes_t nframes, framecnt_t& playback_distance, bool need_disk_signal)
 {
        framecnt_t rec_offset = 0;
        framecnt_t rec_nframes = 0;
@@ -330,17 +356,43 @@ MidiDiskstream::process (framepos_t transport_frame, pframes_t nframes, framecnt
                return 1;
        }
 
+       const Location* const loop_loc    = loop_location;
+       framepos_t            loop_start  = 0;
+       framepos_t            loop_end    = 0;
+       framepos_t            loop_length = 0;
+       get_location_times(loop_loc, &loop_start, &loop_end, &loop_length);
+
        adjust_capture_position = 0;
 
        if (nominally_recording || (re && was_recording && _session.get_record_enabled() && _session.config.get_punch_in())) {
                Evoral::OverlapType ot = Evoral::coverage (first_recordable_frame, last_recordable_frame, transport_frame, transport_frame + nframes);
+               // XXX should this be transport_frame + nframes - 1 ? coverage() expects its parameter ranges to include their end points
 
                calculate_record_range(ot, transport_frame, nframes, rec_nframes, rec_offset);
+               /* For audio: not writing frames to the capture ringbuffer offsets
+                * the recording. For midi: we need to keep track of the record range
+                * and subtract the accumulated difference from the event time.
+                */
+               if (rec_nframes) {
+                       _accumulated_capture_offset += rec_offset;
+               } else {
+                       _accumulated_capture_offset += nframes;
+               }
 
                if (rec_nframes && !was_recording) {
-                       _write_source->mark_write_starting_now ();
-                       g_atomic_int_set(&_frames_pending_write, 0);
-                       capture_captured = 0;
+                       if (loop_loc) {
+                               /* Loop recording, so pretend the capture started at the loop
+                                  start rgardless of what time it is now, so the source starts
+                                  at the loop start and can handle time wrapping around.
+                                  Otherwise, start the source right now as usual.
+                               */
+                               capture_captured    = transport_frame - loop_start;
+                               capture_start_frame = loop_start;
+                       }
+                       _write_source->mark_write_starting_now(
+                               capture_start_frame, capture_captured, loop_length);
+                       g_atomic_int_set(const_cast<gint*> (&_frames_pending_write), 0);
+                       g_atomic_int_set(const_cast<gint*> (&_num_captured_loops), 0);
                        was_recording = true;
                }
        }
@@ -350,13 +402,18 @@ MidiDiskstream::process (framepos_t transport_frame, pframes_t nframes, framecnt
        }
 
        if (nominally_recording || rec_nframes) {
+               // Pump entire port buffer into the ring buffer (TODO: split cycles?)
+               MidiBuffer&        buf    = sp->get_midi_buffer(nframes);
+               MidiTrack*         mt     = dynamic_cast<MidiTrack*>(_track);
+               MidiChannelFilter* filter = mt ? &mt->capture_filter() : NULL;
 
-               // Pump entire port buffer into the ring buffer (FIXME: split cycles?)
-               MidiBuffer& buf = sp->get_midi_buffer(nframes);
                for (MidiBuffer::iterator i = buf.begin(); i != buf.end(); ++i) {
-                       const Evoral::MIDIEvent<MidiBuffer::TimeType> ev(*i, false);
+                       Evoral::MIDIEvent<MidiBuffer::TimeType> ev(*i, false);
+                       if (ev.time() + rec_offset > rec_nframes) {
+                               break;
+                       }
 #ifndef NDEBUG
-                       if (DEBUG::MidiIO & PBD::debug_bits) {
+                       if (DEBUG_ENABLED(DEBUG::MidiIO)) {
                                const uint8_t* __data = ev.buffer();
                                DEBUG_STR_DECL(a);
                                DEBUG_STR_APPEND(a, string_compose ("mididiskstream %1 capture event @ %2 + %3 sz %4 ", this, ev.time(), transport_frame, ev.size()));
@@ -370,9 +427,27 @@ MidiDiskstream::process (framepos_t transport_frame, pframes_t nframes, framecnt
                                DEBUG_TRACE (DEBUG::MidiIO, DEBUG_STR(a).str());
                        }
 #endif
-                       _capture_buf->write(ev.time() + transport_frame, ev.type(), ev.size(), ev.buffer());
+                       /* Write events to the capture buffer in frames from session start,
+                          but ignoring looping so event time progresses monotonically.
+                          The source knows the loop length so it knows exactly where the
+                          event occurs in the series of recorded loops and can implement
+                          any desirable behaviour.  We don't want to send event with
+                          transport time here since that way the source can not
+                          reconstruct their actual time; future clever MIDI looping should
+                          probably be implemented in the source instead of here.
+                       */
+                       const framecnt_t loop_offset = _num_captured_loops * loop_length;
+                       const framepos_t event_time = transport_frame + loop_offset - _accumulated_capture_offset + ev.time();
+                       if (event_time < 0 || event_time < first_recordable_frame) {
+                               /* Event out of range, skip */
+                               continue;
+                       }
+
+                       if (!filter || !filter->filter(ev.buffer(), ev.size())) {
+                               _capture_buf->write(event_time, ev.type(), ev.size(), ev.buffer());
+                       }
                }
-               g_atomic_int_add(&_frames_pending_write, nframes);
+               g_atomic_int_add(const_cast<gint*>(&_frames_pending_write), nframes);
 
                if (buf.size() != 0) {
                        Glib::Threads::Mutex::Lock lm (_gui_feed_buffer_mutex, Glib::Threads::TRY_LOCK);
@@ -382,7 +457,7 @@ MidiDiskstream::process (framepos_t transport_frame, pframes_t nframes, framecnt
                                   that it can read it if it likes.
                                */
                                _gui_feed_buffer.clear ();
-                               
+
                                for (MidiBuffer::iterator i = buf.begin(); i != buf.end(); ++i) {
                                        /* This may fail if buf is larger than _gui_feed_buffer, but it's not really
                                           the end of the world if it does.
@@ -399,6 +474,7 @@ MidiDiskstream::process (framepos_t transport_frame, pframes_t nframes, framecnt
                if (was_recording) {
                        finish_capture ();
                }
+               _accumulated_capture_offset = 0;
 
        }
 
@@ -420,22 +496,66 @@ MidiDiskstream::process (framepos_t transport_frame, pframes_t nframes, framecnt
 
                playback_distance = nframes;
 
-       } else {
+       } else if (_actual_speed != 1.0f && _target_speed > 0) {
 
-               /* XXX: should be doing varispeed stuff here, similar to the code in AudioDiskstream::process */
+               interpolation.set_speed (_target_speed);
 
+               playback_distance = interpolation.distance  (nframes);
+
+       } else {
                playback_distance = nframes;
+       }
+
+       if (need_disk_signal) {
+               /* copy the diskstream data to all output buffers */
+
+               MidiBuffer& mbuf (bufs.get_midi (0));
+               get_playback (mbuf, playback_distance);
+
+               /* leave the audio count alone */
+               ChanCount cnt (DataType::MIDI, 1);
+               cnt.set (DataType::AUDIO, bufs.count().n_audio());
+               bufs.set_count (cnt);
 
+               /* vari-speed */
+               if (_target_speed > 0 && _actual_speed != 1.0f) {
+                       MidiBuffer& mbuf (bufs.get_midi (0));
+                       for (MidiBuffer::iterator i = mbuf.begin(); i != mbuf.end(); ++i) {
+                               MidiBuffer::TimeType *tme = i.timeptr();
+                               *tme = (*tme) * nframes / playback_distance;
+                       }
+               }
        }
 
        return 0;
 }
 
+frameoffset_t
+MidiDiskstream::calculate_playback_distance (pframes_t nframes)
+{
+       frameoffset_t playback_distance = nframes;
+
+       if (!record_enabled() && _actual_speed != 1.0f && _actual_speed > 0.f) {
+               interpolation.set_speed (_target_speed);
+               playback_distance = interpolation.distance (nframes, false);
+       }
+
+       if (_actual_speed < 0.0) {
+               return -playback_distance;
+       } else {
+               return playback_distance;
+       }
+}
+
 bool
 MidiDiskstream::commit (framecnt_t playback_distance)
 {
        bool need_butler = false;
 
+       if (!_io || !_io->active()) {
+               return false;
+       }
+
        if (_actual_speed < 0.0) {
                playback_sample -= playback_distance;
        } else {
@@ -447,8 +567,8 @@ MidiDiskstream::commit (framecnt_t playback_distance)
                adjust_capture_position = 0;
        }
 
-       uint32_t frames_read = g_atomic_int_get(&_frames_read_from_ringbuffer);
-       uint32_t frames_written = g_atomic_int_get(&_frames_written_to_ringbuffer);
+       uint32_t frames_read = g_atomic_int_get(const_cast<gint*>(&_frames_read_from_ringbuffer));
+       uint32_t frames_written = g_atomic_int_get(const_cast<gint*>(&_frames_written_to_ringbuffer));
 
        /*
          cerr << name() << " MDS written: " << frames_written << " - read: " << frames_read <<
@@ -462,11 +582,34 @@ MidiDiskstream::commit (framecnt_t playback_distance)
         * but we do need to check so that the decision on whether or not we
         * need the butler is done correctly.
         */
-       
+
+       /* furthermore..
+        *
+        * Doing heavy GUI operations[1] can stall also the butler.
+        * The RT-thread meanwhile will happily continue and
+        * ‘frames_read’ (from buffer to output) will become larger
+        * than ‘frames_written’ (from disk to buffer).
+        *
+        * The disk-stream is now behind..
+        *
+        * In those cases the butler needs to be summed to refill the buffer (done now)
+        * AND we need to skip (frames_read - frames_written). ie remove old events
+        * before playback_sample from the rinbuffer.
+        *
+        * [1] one way to do so is described at #6170.
+        * For me just popping up the context-menu on a MIDI-track header
+        * of a track with a large (think beethoven :) midi-region also did the
+        * trick. The playhead stalls for 2 or 3 sec, until the context-menu shows.
+        *
+        * In both cases the root cause is that redrawing MIDI regions on the GUI is still very slow
+        * and can stall
+        */
        if (frames_read <= frames_written) {
                if ((frames_written - frames_read) + playback_distance < midi_readahead) {
                        need_butler = true;
                }
+       } else {
+               need_butler = true;
        }
 
 
@@ -485,13 +628,21 @@ MidiDiskstream::set_pending_overwrite (bool yn)
 int
 MidiDiskstream::overwrite_existing_buffers ()
 {
-       /* This is safe as long as the butler thread is suspended, which it should be */
+       /* Clear the playback buffer contents.  This is safe as long as the butler
+          thread is suspended, which it should be. */
        _playback_buf->reset ();
+       _playback_buf->reset_tracker ();
 
        g_atomic_int_set (&_frames_read_from_ringbuffer, 0);
        g_atomic_int_set (&_frames_written_to_ringbuffer, 0);
 
-       read (overwrite_frame, disk_io_chunk_frames, false);
+       /* Resolve all currently active notes in the playlist.  This is more
+          aggressive than it needs to be: ideally we would only resolve what is
+          absolutely necessary, but this seems difficult and/or impossible without
+          having the old data or knowing what change caused the overwrite. */
+       midi_playlist()->resolve_note_trackers (*_playback_buf, overwrite_frame);
+
+       read (overwrite_frame, disk_read_chunk_frames, false);
        file_frame = overwrite_frame; // it was adjusted by ::read()
        overwrite_queued = false;
        _pending_overwrite = false;
@@ -551,29 +702,20 @@ MidiDiskstream::internal_playback_seek (framecnt_t distance)
 int
 MidiDiskstream::read (framepos_t& start, framecnt_t dur, bool reversed)
 {
-       framecnt_t this_read = 0;
-       bool reloop = false;
-       framepos_t loop_end = 0;
-       framepos_t loop_start = 0;
-       Location *loc = 0;
+       framecnt_t this_read   = 0;
+       bool       reloop      = false;
+       framepos_t loop_end    = 0;
+       framepos_t loop_start  = 0;
+       framecnt_t loop_length = 0;
+       Location*  loc         = 0;
 
-       if (!reversed) {
-
-               framecnt_t loop_length = 0;
+       MidiTrack*         mt     = dynamic_cast<MidiTrack*>(_track);
+       MidiChannelFilter* filter = mt ? &mt->playback_filter() : NULL;
 
-               /* Make the use of a Location atomic for this read operation.
-
-                  Note: Locations don't get deleted, so all we care about
-                  when I say "atomic" is that we are always pointing to
-                  the same one and using a start/length values obtained
-                  just once.
-               */
+       if (!reversed) {
 
-               if ((loc = loop_location) != 0) {
-                       loop_start = loc->start();
-                       loop_end = loc->end();
-                       loop_length = loop_end - loop_start;
-               }
+               loc = loop_location;
+               get_location_times(loc, &loop_start, &loop_end, &loop_length);
 
                /* if we are looping, ensure that the first frame we read is at the correct
                   position within the loop.
@@ -606,13 +748,13 @@ MidiDiskstream::read (framepos_t& start, framecnt_t dur, bool reversed)
 
                this_read = min(dur,this_read);
 
-               if (midi_playlist()->read (*_playback_buf, start, this_read) != this_read) {
+               if (midi_playlist()->read (*_playback_buf, start, this_read, 0, filter) != this_read) {
                        error << string_compose(
                                        _("MidiDiskstream %1: cannot read %2 from playlist at frame %3"),
                                        id(), this_read, start) << endmsg;
                        return -1;
                }
-               
+
                g_atomic_int_add (&_frames_written_to_ringbuffer, this_read);
 
                if (reversed) {
@@ -641,7 +783,7 @@ MidiDiskstream::read (framepos_t& start, framecnt_t dur, bool reversed)
 }
 
 int
-MidiDiskstream::do_refill_with_alloc ()
+MidiDiskstream::_do_refill_with_alloc (bool /* partial_fill */)
 {
        return do_refill();
 }
@@ -673,16 +815,17 @@ MidiDiskstream::do_refill ()
 
        uint32_t frames_read = g_atomic_int_get(&_frames_read_from_ringbuffer);
        uint32_t frames_written = g_atomic_int_get(&_frames_written_to_ringbuffer);
-       if ((frames_written - frames_read) >= midi_readahead) {
+       if ((frames_read < frames_written) && (frames_written - frames_read) >= midi_readahead) {
                return 0;
        }
 
-       framecnt_t to_read = midi_readahead - (frames_written - frames_read);
+       framecnt_t to_read = midi_readahead - ((framecnt_t)frames_written - (framecnt_t)frames_read);
 
        //cout << "MDS read for midi_readahead " << to_read << "  rb_contains: "
        //      << frames_written - frames_read << endl;
 
-       to_read = (framecnt_t) min ((framecnt_t) to_read, (framecnt_t) (max_framepos - file_frame));
+       to_read = min (to_read, (framecnt_t) (max_framepos - file_frame));
+       to_read = min (to_read, (framecnt_t) write_space);
 
        if (read (file_frame, to_read, reversed)) {
                ret = -1;
@@ -693,12 +836,12 @@ MidiDiskstream::do_refill ()
 
 /** Flush pending data to disk.
  *
- * Important note: this function will write *AT MOST* disk_io_chunk_frames
+ * Important note: this function will write *AT MOST* disk_write_chunk_frames
  * of data to disk. it will never write more than that.  If it writes that
  * much and there is more than that waiting to be written, it will return 1,
  * otherwise 0 on success or -1 on failure.
  *
- * If there is less than disk_io_chunk_frames to be written, no data will be
+ * If there is less than disk_write_chunk_frames to be written, no data will be
  * written at all unless @a force_flush is true.
  */
 int
@@ -711,16 +854,16 @@ MidiDiskstream::do_flush (RunContext /*context*/, bool force_flush)
                return 0;
        }
 
-       const framecnt_t total = g_atomic_int_get(&_frames_pending_write);
+       const framecnt_t total = g_atomic_int_get(const_cast<gint*> (&_frames_pending_write));
 
-       if (total == 0 || 
-           _capture_buf->read_space() == 0 || 
-           (!force_flush && (total < disk_io_chunk_frames) && was_recording)) {
+       if (total == 0 ||
+           _capture_buf->read_space() == 0 ||
+           (!force_flush && (total < disk_write_chunk_frames) && was_recording)) {
                goto out;
        }
 
        /* if there are 2+ chunks of disk i/o possible for
-          this track, let the caller know so that it can arrange
+          this track), let the caller know so that it can arrange
           for us to be called again, ASAP.
 
           if we are forcing a flush, then if there is* any* extra
@@ -730,7 +873,7 @@ MidiDiskstream::do_flush (RunContext /*context*/, bool force_flush)
           let the caller know too.
           */
 
-       if (total >= 2 * disk_io_chunk_frames || ((force_flush || !was_recording) && total > disk_io_chunk_frames)) {
+       if (total >= 2 * disk_write_chunk_frames || ((force_flush || !was_recording) && total > disk_write_chunk_frames)) {
                ret = 1;
        }
 
@@ -738,15 +881,16 @@ MidiDiskstream::do_flush (RunContext /*context*/, bool force_flush)
                /* push out everything we have, right now */
                to_write = max_framecnt;
        } else {
-               to_write = disk_io_chunk_frames;
+               to_write = disk_write_chunk_frames;
        }
 
-       if (record_enabled() && ((total > disk_io_chunk_frames) || force_flush)) {
-               if (_write_source->midi_write (*_capture_buf, get_capture_start_frame (0), to_write) != to_write) {
+       if (record_enabled() && ((total > disk_write_chunk_frames) || force_flush)) {
+               Source::Lock lm(_write_source->mutex());
+               if (_write_source->midi_write (lm, *_capture_buf, get_capture_start_frame (0), to_write) != to_write) {
                        error << string_compose(_("MidiDiskstream %1: cannot write to disk"), id()) << endmsg;
                        return -1;
-               } 
-               g_atomic_int_add(&_frames_pending_write, -to_write);
+               }
+               g_atomic_int_add(const_cast<gint*> (&_frames_pending_write), -to_write);
        }
 
 out:
@@ -810,6 +954,8 @@ MidiDiskstream::transport_stopped_wallclock (struct tm& /*when*/, time_t /*twhen
 
                        /* phew, we have data */
 
+                       Source::Lock source_lock(_write_source->mutex());
+
                        /* figure out the name for this take */
 
                        srcs.push_back (_write_source);
@@ -820,14 +966,14 @@ MidiDiskstream::transport_stopped_wallclock (struct tm& /*when*/, time_t /*twhen
                        /* set length in beats to entire capture length */
 
                        BeatsFramesConverter converter (_session.tempo_map(), capture_info.front()->start);
-                       const double total_capture_beats = converter.from (total_capture);
+                       const Evoral::Beats total_capture_beats = converter.from (total_capture);
                        _write_source->set_length_beats (total_capture_beats);
 
                        /* flush to disk: this step differs from the audio path,
                           where all the data is already on disk.
                        */
 
-                       _write_source->mark_midi_streaming_write_completed (Evoral::Sequence<Evoral::MusicalTime>::ResolveStuckNotes, total_capture_beats);
+                       _write_source->mark_midi_streaming_write_completed (source_lock, Evoral::Sequence<Evoral::Beats>::ResolveStuckNotes, total_capture_beats);
 
                        /* we will want to be able to keep (over)writing the source
                           but we don't want it to be removable. this also differs
@@ -885,6 +1031,10 @@ MidiDiskstream::transport_stopped_wallclock (struct tm& /*when*/, time_t /*twhen
 
                                RegionFactory::region_name (region_name, _write_source->name(), false);
 
+                               DEBUG_TRACE (DEBUG::CaptureAlignment, string_compose ("%1 capture start @ %2 length %3 add new region %4\n",
+                                                       _name, (*ci)->start, (*ci)->frames, region_name));
+
+
                                // cerr << _name << ": based on ci of " << (*ci)->start << " for " << (*ci)->frames << " add a region\n";
 
                                try {
@@ -946,35 +1096,17 @@ MidiDiskstream::transport_stopped_wallclock (struct tm& /*when*/, time_t /*twhen
 }
 
 void
-MidiDiskstream::transport_looped (framepos_t transport_frame)
+MidiDiskstream::transport_looped (framepos_t)
 {
+       /* Here we only keep track of the number of captured loops so monotonic
+          event times can be delivered to the write source in process().  Trying
+          to be clever here is a world of trouble, it is better to simply record
+          the input in a straightforward non-destructive way.  In the future when
+          we want to implement more clever MIDI looping modes it should be done in
+          the Source and/or entirely after the capture is finished.
+       */
        if (was_recording) {
-
-               // adjust the capture length knowing that the data will be recorded to disk
-               // only necessary after the first loop where we're recording
-               if (capture_info.size() == 0) {
-                       capture_captured += _capture_offset;
-
-                       if (_alignment_style == ExistingMaterial) {
-                               capture_captured += _session.worst_output_latency();
-                       } else {
-                               capture_captured += _roll_delay;
-                       }
-               }
-
-               finish_capture ();
-
-               // the next region will start recording via the normal mechanism
-               // we'll set the start position to the current transport pos
-               // no latency adjustment or capture offset needs to be made, as that already happened the first time
-               capture_start_frame = transport_frame;
-               first_recordable_frame = transport_frame; // mild lie
-               last_recordable_frame = max_framepos;
-               was_recording = true;
-       }
-
-       if (!Config->get_seamless_loop()) {
-               reset_tracker ();
+               g_atomic_int_add(const_cast<gint*> (&_num_captured_loops), 1);
        }
 }
 
@@ -1010,7 +1142,7 @@ MidiDiskstream::finish_capture ()
 void
 MidiDiskstream::set_record_enabled (bool yn)
 {
-       if (!recordable() || !_session.record_enabling_legal() || _io->n_ports().n_midi() == 0) {
+       if (!recordable() || !_session.record_enabling_legal() || _io->n_ports().n_midi() == 0 || record_safe ()) {
                return;
        }
 
@@ -1024,24 +1156,46 @@ MidiDiskstream::set_record_enabled (bool yn)
                } else {
                        disengage_record_enable ();
                }
-               
+
                RecordEnableChanged (); /* EMIT SIGNAL */
        }
 }
 
+void
+MidiDiskstream::set_record_safe (bool yn)
+{
+       if (!recordable() || !_session.record_enabling_legal() || _io->n_ports().n_midi() == 0) { // REQUIRES REVIEW
+               return;
+       }
+
+       /* yes, i know that this not proof against race conditions, but its
+        good enough. i think.
+        */
+
+       if (record_safe () != yn) {
+               if (yn) {
+                       engage_record_safe ();
+               } else {
+                       disengage_record_safe ();
+               }
+
+               RecordSafeChanged (); /* EMIT SIGNAL */
+       }
+}
+
 bool
 MidiDiskstream::prep_record_enable ()
 {
-       if (!recordable() || !_session.record_enabling_legal() || _io->n_ports().n_midi() == 0) {
+       if (!recordable() || !_session.record_enabling_legal() || _io->n_ports().n_midi() == 0 || record_safe ()) { // REQUIRES REVIEW "|| record_safe ()"
                return false;
        }
 
        bool const rolling = _session.transport_speed() != 0.0f;
 
        boost::shared_ptr<MidiPort> sp = _source_port.lock ();
-       
+
        if (sp && Config->get_monitoring_model() == HardwareMonitoring) {
-               sp->request_jack_monitors_input (!(_session.config.get_auto_input() && rolling));
+               sp->request_input_monitoring (!(_session.config.get_auto_input() && rolling));
        }
 
        return true;
@@ -1059,11 +1213,7 @@ MidiDiskstream::get_state ()
 {
        XMLNode& node (Diskstream::get_state());
        char buf[64];
-       LocaleGuard lg (X_("POSIX"));
-
-       node.add_property("channel-mode", enum_2_string(get_channel_mode()));
-       snprintf (buf, sizeof(buf), "0x%x", get_channel_mask());
-       node.add_property("channel-mask", buf);
+       LocaleGuard lg;
 
        if (_write_source && _session.get_record_enabled()) {
 
@@ -1094,11 +1244,10 @@ MidiDiskstream::get_state ()
 int
 MidiDiskstream::set_state (const XMLNode& node, int version)
 {
-       const XMLProperty* prop;
        XMLNodeList nlist = node.children();
        XMLNodeIterator niter;
        XMLNode* capture_pending_node = 0;
-       LocaleGuard lg (X_("POSIX"));
+       LocaleGuard lg;
 
        /* prevent write sources from being created */
 
@@ -1114,26 +1263,10 @@ MidiDiskstream::set_state (const XMLNode& node, int version)
                return -1;
        }
 
-       ChannelMode channel_mode = AllChannels;
-       if ((prop = node.property ("channel-mode")) != 0) {
-               channel_mode = ChannelMode (string_2_enum(prop->value(), channel_mode));
-       }
-
-       unsigned int channel_mask = 0xFFFF;
-       if ((prop = node.property ("channel-mask")) != 0) {
-               sscanf (prop->value().c_str(), "0x%x", &channel_mask);
-               if (channel_mask & (~0xFFFF)) {
-                       warning << _("MidiDiskstream: XML property channel-mask out of range") << endmsg;
-               }
-       }
-
-
        if (capture_pending_node) {
                use_pending_capture_data (*capture_pending_node);
        }
 
-       set_channel_mode (channel_mode, channel_mask);
-
        in_set_state = false;
 
        return 0;
@@ -1146,11 +1279,12 @@ MidiDiskstream::use_new_write_source (uint32_t n)
                return 1;
        }
 
+       _accumulated_capture_offset = 0;
        _write_source.reset();
 
        try {
                _write_source = boost::dynamic_pointer_cast<SMFSource>(
-                       _session.create_midi_source_for_session (0, name ()));
+                       _session.create_midi_source_for_session (write_source_name ()));
 
                if (!_write_source) {
                        throw failed_constructor();
@@ -1165,25 +1299,36 @@ MidiDiskstream::use_new_write_source (uint32_t n)
 
        return 0;
 }
-
-list<boost::shared_ptr<Source> >
-MidiDiskstream::steal_write_sources()
+/**
+ * We want to use the name of the existing write source (the one that will be
+ * used by the next capture) for another purpose. So change the name of the
+ * current source, and return its current name.
+ *
+ * Return an empty string if the change cannot be accomplished.
+ */
+std::string
+MidiDiskstream::steal_write_source_name ()
 {
-       list<boost::shared_ptr<Source> > ret;
-
-       /* put some data on the disk, even if its just a header for an empty file */
-       boost::dynamic_pointer_cast<SMFSource> (_write_source)->ensure_disk_file ();
+       string our_old_name = _write_source->name();
 
-       /* never let it go away */
-       _write_source->mark_nonremovable ();
-
-       ret.push_back (_write_source);
+       /* this will bump the name of the current write source to the next one
+        * (e.g. "MIDI 1-1" gets renamed to "MIDI 1-2"), thus leaving the
+        * current write source name (e.g. "MIDI 1-1" available). See the
+        * comments in Session::create_midi_source_by_stealing_name() about why
+        * we do this.
+        */
 
-       /* get a new one */
+       try {
+               string new_path = _session.new_midi_source_path (name());
 
-       use_new_write_source (0);
+               if (_write_source->rename (new_path)) {
+                       return string();
+               }
+       } catch (...) {
+               return string ();
+       }
 
-       return ret;
+       return our_old_name;
 }
 
 void
@@ -1194,7 +1339,8 @@ MidiDiskstream::reset_write_sources (bool mark_write_complete, bool /*force*/)
        }
 
        if (_write_source && mark_write_complete) {
-               _write_source->mark_streaming_write_completed ();
+               Source::Lock lm(_write_source->mutex());
+               _write_source->mark_streaming_write_completed (lm);
        }
        use_new_write_source (0);
 }
@@ -1210,12 +1356,12 @@ MidiDiskstream::allocate_temporary_buffers ()
 }
 
 void
-MidiDiskstream::ensure_jack_monitors_input (bool yn)
+MidiDiskstream::ensure_input_monitoring (bool yn)
 {
        boost::shared_ptr<MidiPort> sp = _source_port.lock ();
-       
+
        if (sp) {
-               sp->ensure_jack_monitors_input (yn);
+               sp->ensure_input_monitoring (yn);
        }
 }
 
@@ -1238,7 +1384,7 @@ float
 MidiDiskstream::playback_buffer_load () const
 {
        /* For MIDI it's not trivial to differentiate the following two cases:
-          
+
           1.  The playback buffer is empty because the system has run out of time to fill it.
           2.  The playback buffer is empty because there is no more data on the playlist.
 
@@ -1246,7 +1392,7 @@ MidiDiskstream::playback_buffer_load () const
           cannot keep up when #2 happens, when in fact it can.  Since MIDI data rates
           are so low compared to audio, just give a pretend answer here.
        */
-       
+
        return 1;
 }
 
@@ -1254,7 +1400,7 @@ float
 MidiDiskstream::capture_buffer_load () const
 {
        /* We don't report playback buffer load, so don't report capture load either */
-       
+
        return 1;
 }
 
@@ -1283,14 +1429,15 @@ MidiDiskstream::get_playback (MidiBuffer& dst, framecnt_t nframes)
 
        DEBUG_TRACE (DEBUG::MidiDiskstreamIO, string_compose (
                             "%1 MDS pre-read read %8 @ %4..%5 from %2 write to %3, LOOPED ? %6-%7\n", _name,
-                            _playback_buf->get_read_ptr(), _playback_buf->get_write_ptr(), playback_sample, playback_sample + nframes, 
+                            _playback_buf->get_read_ptr(), _playback_buf->get_write_ptr(), playback_sample, playback_sample + nframes,
                             (loc ? loc->start() : -1), (loc ? loc->end() : -1), nframes));
 
         // cerr << "================\n";
         // _playback_buf->dump (cerr);
         // cerr << "----------------\n";
 
-       size_t events_read = 0; 
+       size_t events_read = 0;
+       const size_t split_cycle_offset = Port::port_offset ();
 
        if (loc) {
                framepos_t effective_start;
@@ -1300,7 +1447,7 @@ MidiDiskstream::get_playback (MidiBuffer& dst, framecnt_t nframes)
                } else {
                        effective_start = playback_sample;
                }
-               
+
                DEBUG_TRACE (DEBUG::MidiDiskstreamIO, string_compose ("looped, effective start adjusted to %1\n", effective_start));
 
                if (effective_start == loc->start()) {
@@ -1308,9 +1455,13 @@ MidiDiskstream::get_playback (MidiBuffer& dst, framecnt_t nframes)
                           beyond the loop end.
                        */
 
-                       _playback_buf->loop_resolve (dst, 0);
+                       _playback_buf->resolve_tracker (dst, split_cycle_offset);
                }
 
+               _playback_buf->skip_to (effective_start);
+
+               /* for split-cycles we need to offset the events */
+
                if (loc->end() >= effective_start && loc->end() < effective_start + nframes) {
                        /* end of loop is within the range we are reading, so
                           split the read in two, and lie about the location
@@ -1327,22 +1478,23 @@ MidiDiskstream::get_playback (MidiBuffer& dst, framecnt_t nframes)
                        if (first) {
                                DEBUG_TRACE (DEBUG::MidiDiskstreamIO, string_compose ("loop read #1, from %1 for %2\n",
                                                                                      effective_start, first));
-                               events_read = _playback_buf->read (dst, effective_start, first);
-                       } 
+                               events_read = _playback_buf->read (dst, effective_start, first, split_cycle_offset);
+                       }
 
                        if (second) {
                                DEBUG_TRACE (DEBUG::MidiDiskstreamIO, string_compose ("loop read #2, from %1 for %2\n",
                                                                                      loc->start(), second));
-                               events_read += _playback_buf->read (dst, loc->start(), second);
+                               events_read += _playback_buf->read (dst, loc->start(), second, split_cycle_offset);
                        }
-                                                                   
+
                } else {
                        DEBUG_TRACE (DEBUG::MidiDiskstreamIO, string_compose ("loop read #3, adjusted start as %1 for %2\n",
                                                                              effective_start, nframes));
-                       events_read = _playback_buf->read (dst, effective_start, effective_start + nframes);
+                       events_read = _playback_buf->read (dst, effective_start, effective_start + nframes, split_cycle_offset);
                }
        } else {
-               events_read = _playback_buf->read (dst, playback_sample, playback_sample + nframes);
+               _playback_buf->skip_to (playback_sample);
+               events_read = _playback_buf->read (dst, playback_sample, playback_sample + nframes, split_cycle_offset);
        }
 
        DEBUG_TRACE (DEBUG::MidiDiskstreamIO, string_compose (
@@ -1357,6 +1509,9 @@ MidiDiskstream::get_playback (MidiBuffer& dst, framecnt_t nframes)
 bool
 MidiDiskstream::set_name (string const & name)
 {
+       if (_name == name) {
+               return true;
+       }
        Diskstream::set_name (name);
 
        /* get a new write source so that its name reflects the new diskstream name */
@@ -1365,11 +1520,24 @@ MidiDiskstream::set_name (string const & name)
        return true;
 }
 
+bool
+MidiDiskstream::set_write_source_name (const std::string& str) {
+       if (_write_source_name == str) {
+               return true;
+       }
+       Diskstream::set_write_source_name (str);
+       if (_write_source_name == name()) {
+               return true;
+       }
+       use_new_write_source (0);
+       return true;
+}
+
 boost::shared_ptr<MidiBuffer>
 MidiDiskstream::get_gui_feed_buffer () const
 {
        boost::shared_ptr<MidiBuffer> b (new MidiBuffer (AudioEngine::instance()->raw_buffer_size (DataType::MIDI)));
-       
+
        Glib::Threads::Mutex::Lock lm (_gui_feed_buffer_mutex);
        b->copy (_gui_feed_buffer);
        return b;
@@ -1383,6 +1551,25 @@ MidiDiskstream::reset_tracker ()
        boost::shared_ptr<MidiPlaylist> mp (midi_playlist());
 
        if (mp) {
-               mp->clear_note_trackers ();
+               mp->reset_note_trackers ();
        }
 }
+
+void
+MidiDiskstream::resolve_tracker (Evoral::EventSink<framepos_t>& buffer, framepos_t time)
+{
+       _playback_buf->resolve_tracker(buffer, time);
+
+       boost::shared_ptr<MidiPlaylist> mp (midi_playlist());
+
+       if (mp) {
+               mp->reset_note_trackers ();
+       }
+}
+
+
+boost::shared_ptr<MidiPlaylist>
+MidiDiskstream::midi_playlist ()
+{
+       return boost::dynamic_pointer_cast<MidiPlaylist>(_playlist);
+}