OSDN Git Service

migration/rdma: Split the zero page case from acct_update_position
[qmiga/qemu.git] / migration / ram.c
1 /*
2  * QEMU System Emulator
3  *
4  * Copyright (c) 2003-2008 Fabrice Bellard
5  * Copyright (c) 2011-2015 Red Hat Inc
6  *
7  * Authors:
8  *  Juan Quintela <quintela@redhat.com>
9  *
10  * Permission is hereby granted, free of charge, to any person obtaining a copy
11  * of this software and associated documentation files (the "Software"), to deal
12  * in the Software without restriction, including without limitation the rights
13  * to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
14  * copies of the Software, and to permit persons to whom the Software is
15  * furnished to do so, subject to the following conditions:
16  *
17  * The above copyright notice and this permission notice shall be included in
18  * all copies or substantial portions of the Software.
19  *
20  * THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
21  * IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
22  * FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL
23  * THE AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
24  * LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
25  * OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
26  * THE SOFTWARE.
27  */
28
29 #include "qemu/osdep.h"
30 #include "qemu/cutils.h"
31 #include "qemu/bitops.h"
32 #include "qemu/bitmap.h"
33 #include "qemu/madvise.h"
34 #include "qemu/main-loop.h"
35 #include "io/channel-null.h"
36 #include "xbzrle.h"
37 #include "ram.h"
38 #include "migration.h"
39 #include "migration-stats.h"
40 #include "migration/register.h"
41 #include "migration/misc.h"
42 #include "qemu-file.h"
43 #include "postcopy-ram.h"
44 #include "page_cache.h"
45 #include "qemu/error-report.h"
46 #include "qapi/error.h"
47 #include "qapi/qapi-types-migration.h"
48 #include "qapi/qapi-events-migration.h"
49 #include "qapi/qmp/qerror.h"
50 #include "trace.h"
51 #include "exec/ram_addr.h"
52 #include "exec/target_page.h"
53 #include "qemu/rcu_queue.h"
54 #include "migration/colo.h"
55 #include "block.h"
56 #include "sysemu/cpu-throttle.h"
57 #include "savevm.h"
58 #include "qemu/iov.h"
59 #include "multifd.h"
60 #include "sysemu/runstate.h"
61 #include "options.h"
62
63 #include "hw/boards.h" /* for machine_dump_guest_core() */
64
65 #if defined(__linux__)
66 #include "qemu/userfaultfd.h"
67 #endif /* defined(__linux__) */
68
69 /***********************************************************/
70 /* ram save/restore */
71
72 /*
73  * RAM_SAVE_FLAG_ZERO used to be named RAM_SAVE_FLAG_COMPRESS, it
74  * worked for pages that were filled with the same char.  We switched
75  * it to only search for the zero value.  And to avoid confusion with
76  * RAM_SAVE_FLAG_COMPRESS_PAGE just rename it.
77  */
78 /*
79  * RAM_SAVE_FLAG_FULL was obsoleted in 2009, it can be reused now
80  */
81 #define RAM_SAVE_FLAG_FULL     0x01
82 #define RAM_SAVE_FLAG_ZERO     0x02
83 #define RAM_SAVE_FLAG_MEM_SIZE 0x04
84 #define RAM_SAVE_FLAG_PAGE     0x08
85 #define RAM_SAVE_FLAG_EOS      0x10
86 #define RAM_SAVE_FLAG_CONTINUE 0x20
87 #define RAM_SAVE_FLAG_XBZRLE   0x40
88 /* 0x80 is reserved in qemu-file.h for RAM_SAVE_FLAG_HOOK */
89 #define RAM_SAVE_FLAG_COMPRESS_PAGE    0x100
90 #define RAM_SAVE_FLAG_MULTIFD_FLUSH    0x200
91 /* We can't use any flag that is bigger than 0x200 */
92
93 int (*xbzrle_encode_buffer_func)(uint8_t *, uint8_t *, int,
94      uint8_t *, int) = xbzrle_encode_buffer;
95 #if defined(CONFIG_AVX512BW_OPT)
96 #include "qemu/cpuid.h"
97 static void __attribute__((constructor)) init_cpu_flag(void)
98 {
99     unsigned max = __get_cpuid_max(0, NULL);
100     int a, b, c, d;
101     if (max >= 1) {
102         __cpuid(1, a, b, c, d);
103          /* We must check that AVX is not just available, but usable.  */
104         if ((c & bit_OSXSAVE) && (c & bit_AVX) && max >= 7) {
105             int bv;
106             __asm("xgetbv" : "=a"(bv), "=d"(d) : "c"(0));
107             __cpuid_count(7, 0, a, b, c, d);
108            /* 0xe6:
109             *  XCR0[7:5] = 111b (OPMASK state, upper 256-bit of ZMM0-ZMM15
110             *                    and ZMM16-ZMM31 state are enabled by OS)
111             *  XCR0[2:1] = 11b (XMM state and YMM state are enabled by OS)
112             */
113             if ((bv & 0xe6) == 0xe6 && (b & bit_AVX512BW)) {
114                 xbzrle_encode_buffer_func = xbzrle_encode_buffer_avx512;
115             }
116         }
117     }
118 }
119 #endif
120
121 XBZRLECacheStats xbzrle_counters;
122
123 /* used by the search for pages to send */
124 struct PageSearchStatus {
125     /* The migration channel used for a specific host page */
126     QEMUFile    *pss_channel;
127     /* Last block from where we have sent data */
128     RAMBlock *last_sent_block;
129     /* Current block being searched */
130     RAMBlock    *block;
131     /* Current page to search from */
132     unsigned long page;
133     /* Set once we wrap around */
134     bool         complete_round;
135     /* Whether we're sending a host page */
136     bool          host_page_sending;
137     /* The start/end of current host page.  Invalid if host_page_sending==false */
138     unsigned long host_page_start;
139     unsigned long host_page_end;
140 };
141 typedef struct PageSearchStatus PageSearchStatus;
142
143 /* struct contains XBZRLE cache and a static page
144    used by the compression */
145 static struct {
146     /* buffer used for XBZRLE encoding */
147     uint8_t *encoded_buf;
148     /* buffer for storing page content */
149     uint8_t *current_buf;
150     /* Cache for XBZRLE, Protected by lock. */
151     PageCache *cache;
152     QemuMutex lock;
153     /* it will store a page full of zeros */
154     uint8_t *zero_target_page;
155     /* buffer used for XBZRLE decoding */
156     uint8_t *decoded_buf;
157 } XBZRLE;
158
159 static void XBZRLE_cache_lock(void)
160 {
161     if (migrate_xbzrle()) {
162         qemu_mutex_lock(&XBZRLE.lock);
163     }
164 }
165
166 static void XBZRLE_cache_unlock(void)
167 {
168     if (migrate_xbzrle()) {
169         qemu_mutex_unlock(&XBZRLE.lock);
170     }
171 }
172
173 /**
174  * xbzrle_cache_resize: resize the xbzrle cache
175  *
176  * This function is called from migrate_params_apply in main
177  * thread, possibly while a migration is in progress.  A running
178  * migration may be using the cache and might finish during this call,
179  * hence changes to the cache are protected by XBZRLE.lock().
180  *
181  * Returns 0 for success or -1 for error
182  *
183  * @new_size: new cache size
184  * @errp: set *errp if the check failed, with reason
185  */
186 int xbzrle_cache_resize(uint64_t new_size, Error **errp)
187 {
188     PageCache *new_cache;
189     int64_t ret = 0;
190
191     /* Check for truncation */
192     if (new_size != (size_t)new_size) {
193         error_setg(errp, QERR_INVALID_PARAMETER_VALUE, "cache size",
194                    "exceeding address space");
195         return -1;
196     }
197
198     if (new_size == migrate_xbzrle_cache_size()) {
199         /* nothing to do */
200         return 0;
201     }
202
203     XBZRLE_cache_lock();
204
205     if (XBZRLE.cache != NULL) {
206         new_cache = cache_init(new_size, TARGET_PAGE_SIZE, errp);
207         if (!new_cache) {
208             ret = -1;
209             goto out;
210         }
211
212         cache_fini(XBZRLE.cache);
213         XBZRLE.cache = new_cache;
214     }
215 out:
216     XBZRLE_cache_unlock();
217     return ret;
218 }
219
220 static bool postcopy_preempt_active(void)
221 {
222     return migrate_postcopy_preempt() && migration_in_postcopy();
223 }
224
225 bool ramblock_is_ignored(RAMBlock *block)
226 {
227     return !qemu_ram_is_migratable(block) ||
228            (migrate_ignore_shared() && qemu_ram_is_shared(block));
229 }
230
231 #undef RAMBLOCK_FOREACH
232
233 int foreach_not_ignored_block(RAMBlockIterFunc func, void *opaque)
234 {
235     RAMBlock *block;
236     int ret = 0;
237
238     RCU_READ_LOCK_GUARD();
239
240     RAMBLOCK_FOREACH_NOT_IGNORED(block) {
241         ret = func(block, opaque);
242         if (ret) {
243             break;
244         }
245     }
246     return ret;
247 }
248
249 static void ramblock_recv_map_init(void)
250 {
251     RAMBlock *rb;
252
253     RAMBLOCK_FOREACH_NOT_IGNORED(rb) {
254         assert(!rb->receivedmap);
255         rb->receivedmap = bitmap_new(rb->max_length >> qemu_target_page_bits());
256     }
257 }
258
259 int ramblock_recv_bitmap_test(RAMBlock *rb, void *host_addr)
260 {
261     return test_bit(ramblock_recv_bitmap_offset(host_addr, rb),
262                     rb->receivedmap);
263 }
264
265 bool ramblock_recv_bitmap_test_byte_offset(RAMBlock *rb, uint64_t byte_offset)
266 {
267     return test_bit(byte_offset >> TARGET_PAGE_BITS, rb->receivedmap);
268 }
269
270 void ramblock_recv_bitmap_set(RAMBlock *rb, void *host_addr)
271 {
272     set_bit_atomic(ramblock_recv_bitmap_offset(host_addr, rb), rb->receivedmap);
273 }
274
275 void ramblock_recv_bitmap_set_range(RAMBlock *rb, void *host_addr,
276                                     size_t nr)
277 {
278     bitmap_set_atomic(rb->receivedmap,
279                       ramblock_recv_bitmap_offset(host_addr, rb),
280                       nr);
281 }
282
283 #define  RAMBLOCK_RECV_BITMAP_ENDING  (0x0123456789abcdefULL)
284
285 /*
286  * Format: bitmap_size (8 bytes) + whole_bitmap (N bytes).
287  *
288  * Returns >0 if success with sent bytes, or <0 if error.
289  */
290 int64_t ramblock_recv_bitmap_send(QEMUFile *file,
291                                   const char *block_name)
292 {
293     RAMBlock *block = qemu_ram_block_by_name(block_name);
294     unsigned long *le_bitmap, nbits;
295     uint64_t size;
296
297     if (!block) {
298         error_report("%s: invalid block name: %s", __func__, block_name);
299         return -1;
300     }
301
302     nbits = block->postcopy_length >> TARGET_PAGE_BITS;
303
304     /*
305      * Make sure the tmp bitmap buffer is big enough, e.g., on 32bit
306      * machines we may need 4 more bytes for padding (see below
307      * comment). So extend it a bit before hand.
308      */
309     le_bitmap = bitmap_new(nbits + BITS_PER_LONG);
310
311     /*
312      * Always use little endian when sending the bitmap. This is
313      * required that when source and destination VMs are not using the
314      * same endianness. (Note: big endian won't work.)
315      */
316     bitmap_to_le(le_bitmap, block->receivedmap, nbits);
317
318     /* Size of the bitmap, in bytes */
319     size = DIV_ROUND_UP(nbits, 8);
320
321     /*
322      * size is always aligned to 8 bytes for 64bit machines, but it
323      * may not be true for 32bit machines. We need this padding to
324      * make sure the migration can survive even between 32bit and
325      * 64bit machines.
326      */
327     size = ROUND_UP(size, 8);
328
329     qemu_put_be64(file, size);
330     qemu_put_buffer(file, (const uint8_t *)le_bitmap, size);
331     /*
332      * Mark as an end, in case the middle part is screwed up due to
333      * some "mysterious" reason.
334      */
335     qemu_put_be64(file, RAMBLOCK_RECV_BITMAP_ENDING);
336     qemu_fflush(file);
337
338     g_free(le_bitmap);
339
340     if (qemu_file_get_error(file)) {
341         return qemu_file_get_error(file);
342     }
343
344     return size + sizeof(size);
345 }
346
347 /*
348  * An outstanding page request, on the source, having been received
349  * and queued
350  */
351 struct RAMSrcPageRequest {
352     RAMBlock *rb;
353     hwaddr    offset;
354     hwaddr    len;
355
356     QSIMPLEQ_ENTRY(RAMSrcPageRequest) next_req;
357 };
358
359 /* State of RAM for migration */
360 struct RAMState {
361     /*
362      * PageSearchStatus structures for the channels when send pages.
363      * Protected by the bitmap_mutex.
364      */
365     PageSearchStatus pss[RAM_CHANNEL_MAX];
366     /* UFFD file descriptor, used in 'write-tracking' migration */
367     int uffdio_fd;
368     /* total ram size in bytes */
369     uint64_t ram_bytes_total;
370     /* Last block that we have visited searching for dirty pages */
371     RAMBlock *last_seen_block;
372     /* Last dirty target page we have sent */
373     ram_addr_t last_page;
374     /* last ram version we have seen */
375     uint32_t last_version;
376     /* How many times we have dirty too many pages */
377     int dirty_rate_high_cnt;
378     /* these variables are used for bitmap sync */
379     /* last time we did a full bitmap_sync */
380     int64_t time_last_bitmap_sync;
381     /* bytes transferred at start_time */
382     uint64_t bytes_xfer_prev;
383     /* number of dirty pages since start_time */
384     uint64_t num_dirty_pages_period;
385     /* xbzrle misses since the beginning of the period */
386     uint64_t xbzrle_cache_miss_prev;
387     /* Amount of xbzrle pages since the beginning of the period */
388     uint64_t xbzrle_pages_prev;
389     /* Amount of xbzrle encoded bytes since the beginning of the period */
390     uint64_t xbzrle_bytes_prev;
391     /* Start using XBZRLE (e.g., after the first round). */
392     bool xbzrle_enabled;
393     /* Are we on the last stage of migration */
394     bool last_stage;
395     /* compression statistics since the beginning of the period */
396     /* amount of count that no free thread to compress data */
397     uint64_t compress_thread_busy_prev;
398     /* amount bytes after compression */
399     uint64_t compressed_size_prev;
400     /* amount of compressed pages */
401     uint64_t compress_pages_prev;
402
403     /* total handled target pages at the beginning of period */
404     uint64_t target_page_count_prev;
405     /* total handled target pages since start */
406     uint64_t target_page_count;
407     /* number of dirty bits in the bitmap */
408     uint64_t migration_dirty_pages;
409     /*
410      * Protects:
411      * - dirty/clear bitmap
412      * - migration_dirty_pages
413      * - pss structures
414      */
415     QemuMutex bitmap_mutex;
416     /* The RAMBlock used in the last src_page_requests */
417     RAMBlock *last_req_rb;
418     /* Queue of outstanding page requests from the destination */
419     QemuMutex src_page_req_mutex;
420     QSIMPLEQ_HEAD(, RAMSrcPageRequest) src_page_requests;
421 };
422 typedef struct RAMState RAMState;
423
424 static RAMState *ram_state;
425
426 static NotifierWithReturnList precopy_notifier_list;
427
428 /* Whether postcopy has queued requests? */
429 static bool postcopy_has_request(RAMState *rs)
430 {
431     return !QSIMPLEQ_EMPTY_ATOMIC(&rs->src_page_requests);
432 }
433
434 void precopy_infrastructure_init(void)
435 {
436     notifier_with_return_list_init(&precopy_notifier_list);
437 }
438
439 void precopy_add_notifier(NotifierWithReturn *n)
440 {
441     notifier_with_return_list_add(&precopy_notifier_list, n);
442 }
443
444 void precopy_remove_notifier(NotifierWithReturn *n)
445 {
446     notifier_with_return_remove(n);
447 }
448
449 int precopy_notify(PrecopyNotifyReason reason, Error **errp)
450 {
451     PrecopyNotifyData pnd;
452     pnd.reason = reason;
453     pnd.errp = errp;
454
455     return notifier_with_return_list_notify(&precopy_notifier_list, &pnd);
456 }
457
458 uint64_t ram_bytes_remaining(void)
459 {
460     return ram_state ? (ram_state->migration_dirty_pages * TARGET_PAGE_SIZE) :
461                        0;
462 }
463
464 void ram_transferred_add(uint64_t bytes)
465 {
466     if (runstate_is_running()) {
467         stat64_add(&mig_stats.precopy_bytes, bytes);
468     } else if (migration_in_postcopy()) {
469         stat64_add(&mig_stats.postcopy_bytes, bytes);
470     } else {
471         stat64_add(&mig_stats.downtime_bytes, bytes);
472     }
473     stat64_add(&mig_stats.transferred, bytes);
474 }
475
476 struct MigrationOps {
477     int (*ram_save_target_page)(RAMState *rs, PageSearchStatus *pss);
478 };
479 typedef struct MigrationOps MigrationOps;
480
481 MigrationOps *migration_ops;
482
483 CompressionStats compression_counters;
484
485 struct CompressParam {
486     bool done;
487     bool quit;
488     bool zero_page;
489     QEMUFile *file;
490     QemuMutex mutex;
491     QemuCond cond;
492     RAMBlock *block;
493     ram_addr_t offset;
494
495     /* internally used fields */
496     z_stream stream;
497     uint8_t *originbuf;
498 };
499 typedef struct CompressParam CompressParam;
500
501 struct DecompressParam {
502     bool done;
503     bool quit;
504     QemuMutex mutex;
505     QemuCond cond;
506     void *des;
507     uint8_t *compbuf;
508     int len;
509     z_stream stream;
510 };
511 typedef struct DecompressParam DecompressParam;
512
513 static CompressParam *comp_param;
514 static QemuThread *compress_threads;
515 /* comp_done_cond is used to wake up the migration thread when
516  * one of the compression threads has finished the compression.
517  * comp_done_lock is used to co-work with comp_done_cond.
518  */
519 static QemuMutex comp_done_lock;
520 static QemuCond comp_done_cond;
521
522 static QEMUFile *decomp_file;
523 static DecompressParam *decomp_param;
524 static QemuThread *decompress_threads;
525 static QemuMutex decomp_done_lock;
526 static QemuCond decomp_done_cond;
527
528 static int ram_save_host_page_urgent(PageSearchStatus *pss);
529
530 static bool do_compress_ram_page(QEMUFile *f, z_stream *stream, RAMBlock *block,
531                                  ram_addr_t offset, uint8_t *source_buf);
532
533 /* NOTE: page is the PFN not real ram_addr_t. */
534 static void pss_init(PageSearchStatus *pss, RAMBlock *rb, ram_addr_t page)
535 {
536     pss->block = rb;
537     pss->page = page;
538     pss->complete_round = false;
539 }
540
541 /*
542  * Check whether two PSSs are actively sending the same page.  Return true
543  * if it is, false otherwise.
544  */
545 static bool pss_overlap(PageSearchStatus *pss1, PageSearchStatus *pss2)
546 {
547     return pss1->host_page_sending && pss2->host_page_sending &&
548         (pss1->host_page_start == pss2->host_page_start);
549 }
550
551 static void *do_data_compress(void *opaque)
552 {
553     CompressParam *param = opaque;
554     RAMBlock *block;
555     ram_addr_t offset;
556     bool zero_page;
557
558     qemu_mutex_lock(&param->mutex);
559     while (!param->quit) {
560         if (param->block) {
561             block = param->block;
562             offset = param->offset;
563             param->block = NULL;
564             qemu_mutex_unlock(&param->mutex);
565
566             zero_page = do_compress_ram_page(param->file, &param->stream,
567                                              block, offset, param->originbuf);
568
569             qemu_mutex_lock(&comp_done_lock);
570             param->done = true;
571             param->zero_page = zero_page;
572             qemu_cond_signal(&comp_done_cond);
573             qemu_mutex_unlock(&comp_done_lock);
574
575             qemu_mutex_lock(&param->mutex);
576         } else {
577             qemu_cond_wait(&param->cond, &param->mutex);
578         }
579     }
580     qemu_mutex_unlock(&param->mutex);
581
582     return NULL;
583 }
584
585 static void compress_threads_save_cleanup(void)
586 {
587     int i, thread_count;
588
589     if (!migrate_compress() || !comp_param) {
590         return;
591     }
592
593     thread_count = migrate_compress_threads();
594     for (i = 0; i < thread_count; i++) {
595         /*
596          * we use it as a indicator which shows if the thread is
597          * properly init'd or not
598          */
599         if (!comp_param[i].file) {
600             break;
601         }
602
603         qemu_mutex_lock(&comp_param[i].mutex);
604         comp_param[i].quit = true;
605         qemu_cond_signal(&comp_param[i].cond);
606         qemu_mutex_unlock(&comp_param[i].mutex);
607
608         qemu_thread_join(compress_threads + i);
609         qemu_mutex_destroy(&comp_param[i].mutex);
610         qemu_cond_destroy(&comp_param[i].cond);
611         deflateEnd(&comp_param[i].stream);
612         g_free(comp_param[i].originbuf);
613         qemu_fclose(comp_param[i].file);
614         comp_param[i].file = NULL;
615     }
616     qemu_mutex_destroy(&comp_done_lock);
617     qemu_cond_destroy(&comp_done_cond);
618     g_free(compress_threads);
619     g_free(comp_param);
620     compress_threads = NULL;
621     comp_param = NULL;
622 }
623
624 static int compress_threads_save_setup(void)
625 {
626     int i, thread_count;
627
628     if (!migrate_compress()) {
629         return 0;
630     }
631     thread_count = migrate_compress_threads();
632     compress_threads = g_new0(QemuThread, thread_count);
633     comp_param = g_new0(CompressParam, thread_count);
634     qemu_cond_init(&comp_done_cond);
635     qemu_mutex_init(&comp_done_lock);
636     for (i = 0; i < thread_count; i++) {
637         comp_param[i].originbuf = g_try_malloc(TARGET_PAGE_SIZE);
638         if (!comp_param[i].originbuf) {
639             goto exit;
640         }
641
642         if (deflateInit(&comp_param[i].stream,
643                         migrate_compress_level()) != Z_OK) {
644             g_free(comp_param[i].originbuf);
645             goto exit;
646         }
647
648         /* comp_param[i].file is just used as a dummy buffer to save data,
649          * set its ops to empty.
650          */
651         comp_param[i].file = qemu_file_new_output(
652             QIO_CHANNEL(qio_channel_null_new()));
653         comp_param[i].done = true;
654         comp_param[i].quit = false;
655         qemu_mutex_init(&comp_param[i].mutex);
656         qemu_cond_init(&comp_param[i].cond);
657         qemu_thread_create(compress_threads + i, "compress",
658                            do_data_compress, comp_param + i,
659                            QEMU_THREAD_JOINABLE);
660     }
661     return 0;
662
663 exit:
664     compress_threads_save_cleanup();
665     return -1;
666 }
667
668 /**
669  * save_page_header: write page header to wire
670  *
671  * If this is the 1st block, it also writes the block identification
672  *
673  * Returns the number of bytes written
674  *
675  * @pss: current PSS channel status
676  * @block: block that contains the page we want to send
677  * @offset: offset inside the block for the page
678  *          in the lower bits, it contains flags
679  */
680 static size_t save_page_header(PageSearchStatus *pss, QEMUFile *f,
681                                RAMBlock *block, ram_addr_t offset)
682 {
683     size_t size, len;
684     bool same_block = (block == pss->last_sent_block);
685
686     if (same_block) {
687         offset |= RAM_SAVE_FLAG_CONTINUE;
688     }
689     qemu_put_be64(f, offset);
690     size = 8;
691
692     if (!same_block) {
693         len = strlen(block->idstr);
694         qemu_put_byte(f, len);
695         qemu_put_buffer(f, (uint8_t *)block->idstr, len);
696         size += 1 + len;
697         pss->last_sent_block = block;
698     }
699     return size;
700 }
701
702 /**
703  * mig_throttle_guest_down: throttle down the guest
704  *
705  * Reduce amount of guest cpu execution to hopefully slow down memory
706  * writes. If guest dirty memory rate is reduced below the rate at
707  * which we can transfer pages to the destination then we should be
708  * able to complete migration. Some workloads dirty memory way too
709  * fast and will not effectively converge, even with auto-converge.
710  */
711 static void mig_throttle_guest_down(uint64_t bytes_dirty_period,
712                                     uint64_t bytes_dirty_threshold)
713 {
714     uint64_t pct_initial = migrate_cpu_throttle_initial();
715     uint64_t pct_increment = migrate_cpu_throttle_increment();
716     bool pct_tailslow = migrate_cpu_throttle_tailslow();
717     int pct_max = migrate_max_cpu_throttle();
718
719     uint64_t throttle_now = cpu_throttle_get_percentage();
720     uint64_t cpu_now, cpu_ideal, throttle_inc;
721
722     /* We have not started throttling yet. Let's start it. */
723     if (!cpu_throttle_active()) {
724         cpu_throttle_set(pct_initial);
725     } else {
726         /* Throttling already on, just increase the rate */
727         if (!pct_tailslow) {
728             throttle_inc = pct_increment;
729         } else {
730             /* Compute the ideal CPU percentage used by Guest, which may
731              * make the dirty rate match the dirty rate threshold. */
732             cpu_now = 100 - throttle_now;
733             cpu_ideal = cpu_now * (bytes_dirty_threshold * 1.0 /
734                         bytes_dirty_period);
735             throttle_inc = MIN(cpu_now - cpu_ideal, pct_increment);
736         }
737         cpu_throttle_set(MIN(throttle_now + throttle_inc, pct_max));
738     }
739 }
740
741 void mig_throttle_counter_reset(void)
742 {
743     RAMState *rs = ram_state;
744
745     rs->time_last_bitmap_sync = qemu_clock_get_ms(QEMU_CLOCK_REALTIME);
746     rs->num_dirty_pages_period = 0;
747     rs->bytes_xfer_prev = stat64_get(&mig_stats.transferred);
748 }
749
750 /**
751  * xbzrle_cache_zero_page: insert a zero page in the XBZRLE cache
752  *
753  * @rs: current RAM state
754  * @current_addr: address for the zero page
755  *
756  * Update the xbzrle cache to reflect a page that's been sent as all 0.
757  * The important thing is that a stale (not-yet-0'd) page be replaced
758  * by the new data.
759  * As a bonus, if the page wasn't in the cache it gets added so that
760  * when a small write is made into the 0'd page it gets XBZRLE sent.
761  */
762 static void xbzrle_cache_zero_page(RAMState *rs, ram_addr_t current_addr)
763 {
764     /* We don't care if this fails to allocate a new cache page
765      * as long as it updated an old one */
766     cache_insert(XBZRLE.cache, current_addr, XBZRLE.zero_target_page,
767                  stat64_get(&mig_stats.dirty_sync_count));
768 }
769
770 #define ENCODING_FLAG_XBZRLE 0x1
771
772 /**
773  * save_xbzrle_page: compress and send current page
774  *
775  * Returns: 1 means that we wrote the page
776  *          0 means that page is identical to the one already sent
777  *          -1 means that xbzrle would be longer than normal
778  *
779  * @rs: current RAM state
780  * @pss: current PSS channel
781  * @current_data: pointer to the address of the page contents
782  * @current_addr: addr of the page
783  * @block: block that contains the page we want to send
784  * @offset: offset inside the block for the page
785  */
786 static int save_xbzrle_page(RAMState *rs, PageSearchStatus *pss,
787                             uint8_t **current_data, ram_addr_t current_addr,
788                             RAMBlock *block, ram_addr_t offset)
789 {
790     int encoded_len = 0, bytes_xbzrle;
791     uint8_t *prev_cached_page;
792     QEMUFile *file = pss->pss_channel;
793     uint64_t generation = stat64_get(&mig_stats.dirty_sync_count);
794
795     if (!cache_is_cached(XBZRLE.cache, current_addr, generation)) {
796         xbzrle_counters.cache_miss++;
797         if (!rs->last_stage) {
798             if (cache_insert(XBZRLE.cache, current_addr, *current_data,
799                              generation) == -1) {
800                 return -1;
801             } else {
802                 /* update *current_data when the page has been
803                    inserted into cache */
804                 *current_data = get_cached_data(XBZRLE.cache, current_addr);
805             }
806         }
807         return -1;
808     }
809
810     /*
811      * Reaching here means the page has hit the xbzrle cache, no matter what
812      * encoding result it is (normal encoding, overflow or skipping the page),
813      * count the page as encoded. This is used to calculate the encoding rate.
814      *
815      * Example: 2 pages (8KB) being encoded, first page encoding generates 2KB,
816      * 2nd page turns out to be skipped (i.e. no new bytes written to the
817      * page), the overall encoding rate will be 8KB / 2KB = 4, which has the
818      * skipped page included. In this way, the encoding rate can tell if the
819      * guest page is good for xbzrle encoding.
820      */
821     xbzrle_counters.pages++;
822     prev_cached_page = get_cached_data(XBZRLE.cache, current_addr);
823
824     /* save current buffer into memory */
825     memcpy(XBZRLE.current_buf, *current_data, TARGET_PAGE_SIZE);
826
827     /* XBZRLE encoding (if there is no overflow) */
828     encoded_len = xbzrle_encode_buffer_func(prev_cached_page, XBZRLE.current_buf,
829                                             TARGET_PAGE_SIZE, XBZRLE.encoded_buf,
830                                             TARGET_PAGE_SIZE);
831
832     /*
833      * Update the cache contents, so that it corresponds to the data
834      * sent, in all cases except where we skip the page.
835      */
836     if (!rs->last_stage && encoded_len != 0) {
837         memcpy(prev_cached_page, XBZRLE.current_buf, TARGET_PAGE_SIZE);
838         /*
839          * In the case where we couldn't compress, ensure that the caller
840          * sends the data from the cache, since the guest might have
841          * changed the RAM since we copied it.
842          */
843         *current_data = prev_cached_page;
844     }
845
846     if (encoded_len == 0) {
847         trace_save_xbzrle_page_skipping();
848         return 0;
849     } else if (encoded_len == -1) {
850         trace_save_xbzrle_page_overflow();
851         xbzrle_counters.overflow++;
852         xbzrle_counters.bytes += TARGET_PAGE_SIZE;
853         return -1;
854     }
855
856     /* Send XBZRLE based compressed page */
857     bytes_xbzrle = save_page_header(pss, pss->pss_channel, block,
858                                     offset | RAM_SAVE_FLAG_XBZRLE);
859     qemu_put_byte(file, ENCODING_FLAG_XBZRLE);
860     qemu_put_be16(file, encoded_len);
861     qemu_put_buffer(file, XBZRLE.encoded_buf, encoded_len);
862     bytes_xbzrle += encoded_len + 1 + 2;
863     /*
864      * Like compressed_size (please see update_compress_thread_counts),
865      * the xbzrle encoded bytes don't count the 8 byte header with
866      * RAM_SAVE_FLAG_CONTINUE.
867      */
868     xbzrle_counters.bytes += bytes_xbzrle - 8;
869     ram_transferred_add(bytes_xbzrle);
870
871     return 1;
872 }
873
874 /**
875  * pss_find_next_dirty: find the next dirty page of current ramblock
876  *
877  * This function updates pss->page to point to the next dirty page index
878  * within the ramblock to migrate, or the end of ramblock when nothing
879  * found.  Note that when pss->host_page_sending==true it means we're
880  * during sending a host page, so we won't look for dirty page that is
881  * outside the host page boundary.
882  *
883  * @pss: the current page search status
884  */
885 static void pss_find_next_dirty(PageSearchStatus *pss)
886 {
887     RAMBlock *rb = pss->block;
888     unsigned long size = rb->used_length >> TARGET_PAGE_BITS;
889     unsigned long *bitmap = rb->bmap;
890
891     if (ramblock_is_ignored(rb)) {
892         /* Points directly to the end, so we know no dirty page */
893         pss->page = size;
894         return;
895     }
896
897     /*
898      * If during sending a host page, only look for dirty pages within the
899      * current host page being send.
900      */
901     if (pss->host_page_sending) {
902         assert(pss->host_page_end);
903         size = MIN(size, pss->host_page_end);
904     }
905
906     pss->page = find_next_bit(bitmap, size, pss->page);
907 }
908
909 static void migration_clear_memory_region_dirty_bitmap(RAMBlock *rb,
910                                                        unsigned long page)
911 {
912     uint8_t shift;
913     hwaddr size, start;
914
915     if (!rb->clear_bmap || !clear_bmap_test_and_clear(rb, page)) {
916         return;
917     }
918
919     shift = rb->clear_bmap_shift;
920     /*
921      * CLEAR_BITMAP_SHIFT_MIN should always guarantee this... this
922      * can make things easier sometimes since then start address
923      * of the small chunk will always be 64 pages aligned so the
924      * bitmap will always be aligned to unsigned long. We should
925      * even be able to remove this restriction but I'm simply
926      * keeping it.
927      */
928     assert(shift >= 6);
929
930     size = 1ULL << (TARGET_PAGE_BITS + shift);
931     start = QEMU_ALIGN_DOWN((ram_addr_t)page << TARGET_PAGE_BITS, size);
932     trace_migration_bitmap_clear_dirty(rb->idstr, start, size, page);
933     memory_region_clear_dirty_bitmap(rb->mr, start, size);
934 }
935
936 static void
937 migration_clear_memory_region_dirty_bitmap_range(RAMBlock *rb,
938                                                  unsigned long start,
939                                                  unsigned long npages)
940 {
941     unsigned long i, chunk_pages = 1UL << rb->clear_bmap_shift;
942     unsigned long chunk_start = QEMU_ALIGN_DOWN(start, chunk_pages);
943     unsigned long chunk_end = QEMU_ALIGN_UP(start + npages, chunk_pages);
944
945     /*
946      * Clear pages from start to start + npages - 1, so the end boundary is
947      * exclusive.
948      */
949     for (i = chunk_start; i < chunk_end; i += chunk_pages) {
950         migration_clear_memory_region_dirty_bitmap(rb, i);
951     }
952 }
953
954 /*
955  * colo_bitmap_find_diry:find contiguous dirty pages from start
956  *
957  * Returns the page offset within memory region of the start of the contiguout
958  * dirty page
959  *
960  * @rs: current RAM state
961  * @rb: RAMBlock where to search for dirty pages
962  * @start: page where we start the search
963  * @num: the number of contiguous dirty pages
964  */
965 static inline
966 unsigned long colo_bitmap_find_dirty(RAMState *rs, RAMBlock *rb,
967                                      unsigned long start, unsigned long *num)
968 {
969     unsigned long size = rb->used_length >> TARGET_PAGE_BITS;
970     unsigned long *bitmap = rb->bmap;
971     unsigned long first, next;
972
973     *num = 0;
974
975     if (ramblock_is_ignored(rb)) {
976         return size;
977     }
978
979     first = find_next_bit(bitmap, size, start);
980     if (first >= size) {
981         return first;
982     }
983     next = find_next_zero_bit(bitmap, size, first + 1);
984     assert(next >= first);
985     *num = next - first;
986     return first;
987 }
988
989 static inline bool migration_bitmap_clear_dirty(RAMState *rs,
990                                                 RAMBlock *rb,
991                                                 unsigned long page)
992 {
993     bool ret;
994
995     /*
996      * Clear dirty bitmap if needed.  This _must_ be called before we
997      * send any of the page in the chunk because we need to make sure
998      * we can capture further page content changes when we sync dirty
999      * log the next time.  So as long as we are going to send any of
1000      * the page in the chunk we clear the remote dirty bitmap for all.
1001      * Clearing it earlier won't be a problem, but too late will.
1002      */
1003     migration_clear_memory_region_dirty_bitmap(rb, page);
1004
1005     ret = test_and_clear_bit(page, rb->bmap);
1006     if (ret) {
1007         rs->migration_dirty_pages--;
1008     }
1009
1010     return ret;
1011 }
1012
1013 static void dirty_bitmap_clear_section(MemoryRegionSection *section,
1014                                        void *opaque)
1015 {
1016     const hwaddr offset = section->offset_within_region;
1017     const hwaddr size = int128_get64(section->size);
1018     const unsigned long start = offset >> TARGET_PAGE_BITS;
1019     const unsigned long npages = size >> TARGET_PAGE_BITS;
1020     RAMBlock *rb = section->mr->ram_block;
1021     uint64_t *cleared_bits = opaque;
1022
1023     /*
1024      * We don't grab ram_state->bitmap_mutex because we expect to run
1025      * only when starting migration or during postcopy recovery where
1026      * we don't have concurrent access.
1027      */
1028     if (!migration_in_postcopy() && !migrate_background_snapshot()) {
1029         migration_clear_memory_region_dirty_bitmap_range(rb, start, npages);
1030     }
1031     *cleared_bits += bitmap_count_one_with_offset(rb->bmap, start, npages);
1032     bitmap_clear(rb->bmap, start, npages);
1033 }
1034
1035 /*
1036  * Exclude all dirty pages from migration that fall into a discarded range as
1037  * managed by a RamDiscardManager responsible for the mapped memory region of
1038  * the RAMBlock. Clear the corresponding bits in the dirty bitmaps.
1039  *
1040  * Discarded pages ("logically unplugged") have undefined content and must
1041  * not get migrated, because even reading these pages for migration might
1042  * result in undesired behavior.
1043  *
1044  * Returns the number of cleared bits in the RAMBlock dirty bitmap.
1045  *
1046  * Note: The result is only stable while migrating (precopy/postcopy).
1047  */
1048 static uint64_t ramblock_dirty_bitmap_clear_discarded_pages(RAMBlock *rb)
1049 {
1050     uint64_t cleared_bits = 0;
1051
1052     if (rb->mr && rb->bmap && memory_region_has_ram_discard_manager(rb->mr)) {
1053         RamDiscardManager *rdm = memory_region_get_ram_discard_manager(rb->mr);
1054         MemoryRegionSection section = {
1055             .mr = rb->mr,
1056             .offset_within_region = 0,
1057             .size = int128_make64(qemu_ram_get_used_length(rb)),
1058         };
1059
1060         ram_discard_manager_replay_discarded(rdm, &section,
1061                                              dirty_bitmap_clear_section,
1062                                              &cleared_bits);
1063     }
1064     return cleared_bits;
1065 }
1066
1067 /*
1068  * Check if a host-page aligned page falls into a discarded range as managed by
1069  * a RamDiscardManager responsible for the mapped memory region of the RAMBlock.
1070  *
1071  * Note: The result is only stable while migrating (precopy/postcopy).
1072  */
1073 bool ramblock_page_is_discarded(RAMBlock *rb, ram_addr_t start)
1074 {
1075     if (rb->mr && memory_region_has_ram_discard_manager(rb->mr)) {
1076         RamDiscardManager *rdm = memory_region_get_ram_discard_manager(rb->mr);
1077         MemoryRegionSection section = {
1078             .mr = rb->mr,
1079             .offset_within_region = start,
1080             .size = int128_make64(qemu_ram_pagesize(rb)),
1081         };
1082
1083         return !ram_discard_manager_is_populated(rdm, &section);
1084     }
1085     return false;
1086 }
1087
1088 /* Called with RCU critical section */
1089 static void ramblock_sync_dirty_bitmap(RAMState *rs, RAMBlock *rb)
1090 {
1091     uint64_t new_dirty_pages =
1092         cpu_physical_memory_sync_dirty_bitmap(rb, 0, rb->used_length);
1093
1094     rs->migration_dirty_pages += new_dirty_pages;
1095     rs->num_dirty_pages_period += new_dirty_pages;
1096 }
1097
1098 /**
1099  * ram_pagesize_summary: calculate all the pagesizes of a VM
1100  *
1101  * Returns a summary bitmap of the page sizes of all RAMBlocks
1102  *
1103  * For VMs with just normal pages this is equivalent to the host page
1104  * size. If it's got some huge pages then it's the OR of all the
1105  * different page sizes.
1106  */
1107 uint64_t ram_pagesize_summary(void)
1108 {
1109     RAMBlock *block;
1110     uint64_t summary = 0;
1111
1112     RAMBLOCK_FOREACH_NOT_IGNORED(block) {
1113         summary |= block->page_size;
1114     }
1115
1116     return summary;
1117 }
1118
1119 uint64_t ram_get_total_transferred_pages(void)
1120 {
1121     return stat64_get(&mig_stats.normal_pages) +
1122         stat64_get(&mig_stats.zero_pages) +
1123         compression_counters.pages + xbzrle_counters.pages;
1124 }
1125
1126 static void migration_update_rates(RAMState *rs, int64_t end_time)
1127 {
1128     uint64_t page_count = rs->target_page_count - rs->target_page_count_prev;
1129     double compressed_size;
1130
1131     /* calculate period counters */
1132     stat64_set(&mig_stats.dirty_pages_rate,
1133                rs->num_dirty_pages_period * 1000 /
1134                (end_time - rs->time_last_bitmap_sync));
1135
1136     if (!page_count) {
1137         return;
1138     }
1139
1140     if (migrate_xbzrle()) {
1141         double encoded_size, unencoded_size;
1142
1143         xbzrle_counters.cache_miss_rate = (double)(xbzrle_counters.cache_miss -
1144             rs->xbzrle_cache_miss_prev) / page_count;
1145         rs->xbzrle_cache_miss_prev = xbzrle_counters.cache_miss;
1146         unencoded_size = (xbzrle_counters.pages - rs->xbzrle_pages_prev) *
1147                          TARGET_PAGE_SIZE;
1148         encoded_size = xbzrle_counters.bytes - rs->xbzrle_bytes_prev;
1149         if (xbzrle_counters.pages == rs->xbzrle_pages_prev || !encoded_size) {
1150             xbzrle_counters.encoding_rate = 0;
1151         } else {
1152             xbzrle_counters.encoding_rate = unencoded_size / encoded_size;
1153         }
1154         rs->xbzrle_pages_prev = xbzrle_counters.pages;
1155         rs->xbzrle_bytes_prev = xbzrle_counters.bytes;
1156     }
1157
1158     if (migrate_compress()) {
1159         compression_counters.busy_rate = (double)(compression_counters.busy -
1160             rs->compress_thread_busy_prev) / page_count;
1161         rs->compress_thread_busy_prev = compression_counters.busy;
1162
1163         compressed_size = compression_counters.compressed_size -
1164                           rs->compressed_size_prev;
1165         if (compressed_size) {
1166             double uncompressed_size = (compression_counters.pages -
1167                                     rs->compress_pages_prev) * TARGET_PAGE_SIZE;
1168
1169             /* Compression-Ratio = Uncompressed-size / Compressed-size */
1170             compression_counters.compression_rate =
1171                                         uncompressed_size / compressed_size;
1172
1173             rs->compress_pages_prev = compression_counters.pages;
1174             rs->compressed_size_prev = compression_counters.compressed_size;
1175         }
1176     }
1177 }
1178
1179 static void migration_trigger_throttle(RAMState *rs)
1180 {
1181     uint64_t threshold = migrate_throttle_trigger_threshold();
1182     uint64_t bytes_xfer_period =
1183         stat64_get(&mig_stats.transferred) - rs->bytes_xfer_prev;
1184     uint64_t bytes_dirty_period = rs->num_dirty_pages_period * TARGET_PAGE_SIZE;
1185     uint64_t bytes_dirty_threshold = bytes_xfer_period * threshold / 100;
1186
1187     /* During block migration the auto-converge logic incorrectly detects
1188      * that ram migration makes no progress. Avoid this by disabling the
1189      * throttling logic during the bulk phase of block migration. */
1190     if (migrate_auto_converge() && !blk_mig_bulk_active()) {
1191         /* The following detection logic can be refined later. For now:
1192            Check to see if the ratio between dirtied bytes and the approx.
1193            amount of bytes that just got transferred since the last time
1194            we were in this routine reaches the threshold. If that happens
1195            twice, start or increase throttling. */
1196
1197         if ((bytes_dirty_period > bytes_dirty_threshold) &&
1198             (++rs->dirty_rate_high_cnt >= 2)) {
1199             trace_migration_throttle();
1200             rs->dirty_rate_high_cnt = 0;
1201             mig_throttle_guest_down(bytes_dirty_period,
1202                                     bytes_dirty_threshold);
1203         }
1204     }
1205 }
1206
1207 static void migration_bitmap_sync(RAMState *rs)
1208 {
1209     RAMBlock *block;
1210     int64_t end_time;
1211
1212     stat64_add(&mig_stats.dirty_sync_count, 1);
1213
1214     if (!rs->time_last_bitmap_sync) {
1215         rs->time_last_bitmap_sync = qemu_clock_get_ms(QEMU_CLOCK_REALTIME);
1216     }
1217
1218     trace_migration_bitmap_sync_start();
1219     memory_global_dirty_log_sync();
1220
1221     qemu_mutex_lock(&rs->bitmap_mutex);
1222     WITH_RCU_READ_LOCK_GUARD() {
1223         RAMBLOCK_FOREACH_NOT_IGNORED(block) {
1224             ramblock_sync_dirty_bitmap(rs, block);
1225         }
1226         stat64_set(&mig_stats.dirty_bytes_last_sync, ram_bytes_remaining());
1227     }
1228     qemu_mutex_unlock(&rs->bitmap_mutex);
1229
1230     memory_global_after_dirty_log_sync();
1231     trace_migration_bitmap_sync_end(rs->num_dirty_pages_period);
1232
1233     end_time = qemu_clock_get_ms(QEMU_CLOCK_REALTIME);
1234
1235     /* more than 1 second = 1000 millisecons */
1236     if (end_time > rs->time_last_bitmap_sync + 1000) {
1237         migration_trigger_throttle(rs);
1238
1239         migration_update_rates(rs, end_time);
1240
1241         rs->target_page_count_prev = rs->target_page_count;
1242
1243         /* reset period counters */
1244         rs->time_last_bitmap_sync = end_time;
1245         rs->num_dirty_pages_period = 0;
1246         rs->bytes_xfer_prev = stat64_get(&mig_stats.transferred);
1247     }
1248     if (migrate_events()) {
1249         uint64_t generation = stat64_get(&mig_stats.dirty_sync_count);
1250         qapi_event_send_migration_pass(generation);
1251     }
1252 }
1253
1254 static void migration_bitmap_sync_precopy(RAMState *rs)
1255 {
1256     Error *local_err = NULL;
1257
1258     /*
1259      * The current notifier usage is just an optimization to migration, so we
1260      * don't stop the normal migration process in the error case.
1261      */
1262     if (precopy_notify(PRECOPY_NOTIFY_BEFORE_BITMAP_SYNC, &local_err)) {
1263         error_report_err(local_err);
1264         local_err = NULL;
1265     }
1266
1267     migration_bitmap_sync(rs);
1268
1269     if (precopy_notify(PRECOPY_NOTIFY_AFTER_BITMAP_SYNC, &local_err)) {
1270         error_report_err(local_err);
1271     }
1272 }
1273
1274 void ram_release_page(const char *rbname, uint64_t offset)
1275 {
1276     if (!migrate_release_ram() || !migration_in_postcopy()) {
1277         return;
1278     }
1279
1280     ram_discard_range(rbname, offset, TARGET_PAGE_SIZE);
1281 }
1282
1283 /**
1284  * save_zero_page_to_file: send the zero page to the file
1285  *
1286  * Returns the size of data written to the file, 0 means the page is not
1287  * a zero page
1288  *
1289  * @pss: current PSS channel
1290  * @block: block that contains the page we want to send
1291  * @offset: offset inside the block for the page
1292  */
1293 static int save_zero_page_to_file(PageSearchStatus *pss, QEMUFile *file,
1294                                   RAMBlock *block, ram_addr_t offset)
1295 {
1296     uint8_t *p = block->host + offset;
1297     int len = 0;
1298
1299     if (buffer_is_zero(p, TARGET_PAGE_SIZE)) {
1300         len += save_page_header(pss, file, block, offset | RAM_SAVE_FLAG_ZERO);
1301         qemu_put_byte(file, 0);
1302         len += 1;
1303         ram_release_page(block->idstr, offset);
1304     }
1305     return len;
1306 }
1307
1308 /**
1309  * save_zero_page: send the zero page to the stream
1310  *
1311  * Returns the number of pages written.
1312  *
1313  * @pss: current PSS channel
1314  * @block: block that contains the page we want to send
1315  * @offset: offset inside the block for the page
1316  */
1317 static int save_zero_page(PageSearchStatus *pss, QEMUFile *f, RAMBlock *block,
1318                           ram_addr_t offset)
1319 {
1320     int len = save_zero_page_to_file(pss, f, block, offset);
1321
1322     if (len) {
1323         stat64_add(&mig_stats.zero_pages, 1);
1324         ram_transferred_add(len);
1325         return 1;
1326     }
1327     return -1;
1328 }
1329
1330 /*
1331  * @pages: the number of pages written by the control path,
1332  *        < 0 - error
1333  *        > 0 - number of pages written
1334  *
1335  * Return true if the pages has been saved, otherwise false is returned.
1336  */
1337 static bool control_save_page(PageSearchStatus *pss, RAMBlock *block,
1338                               ram_addr_t offset, int *pages)
1339 {
1340     uint64_t bytes_xmit = 0;
1341     int ret;
1342
1343     *pages = -1;
1344     ret = ram_control_save_page(pss->pss_channel, block->offset, offset,
1345                                 TARGET_PAGE_SIZE, &bytes_xmit);
1346     if (ret == RAM_SAVE_CONTROL_NOT_SUPP) {
1347         return false;
1348     }
1349
1350     if (bytes_xmit) {
1351         ram_transferred_add(bytes_xmit);
1352         *pages = 1;
1353     }
1354
1355     if (ret == RAM_SAVE_CONTROL_DELAYED) {
1356         return true;
1357     }
1358
1359     if (bytes_xmit > 0) {
1360         stat64_add(&mig_stats.normal_pages, 1);
1361     } else if (bytes_xmit == 0) {
1362         stat64_add(&mig_stats.zero_pages, 1);
1363     }
1364
1365     return true;
1366 }
1367
1368 /*
1369  * directly send the page to the stream
1370  *
1371  * Returns the number of pages written.
1372  *
1373  * @pss: current PSS channel
1374  * @block: block that contains the page we want to send
1375  * @offset: offset inside the block for the page
1376  * @buf: the page to be sent
1377  * @async: send to page asyncly
1378  */
1379 static int save_normal_page(PageSearchStatus *pss, RAMBlock *block,
1380                             ram_addr_t offset, uint8_t *buf, bool async)
1381 {
1382     QEMUFile *file = pss->pss_channel;
1383
1384     ram_transferred_add(save_page_header(pss, pss->pss_channel, block,
1385                                          offset | RAM_SAVE_FLAG_PAGE));
1386     if (async) {
1387         qemu_put_buffer_async(file, buf, TARGET_PAGE_SIZE,
1388                               migrate_release_ram() &&
1389                               migration_in_postcopy());
1390     } else {
1391         qemu_put_buffer(file, buf, TARGET_PAGE_SIZE);
1392     }
1393     ram_transferred_add(TARGET_PAGE_SIZE);
1394     stat64_add(&mig_stats.normal_pages, 1);
1395     return 1;
1396 }
1397
1398 /**
1399  * ram_save_page: send the given page to the stream
1400  *
1401  * Returns the number of pages written.
1402  *          < 0 - error
1403  *          >=0 - Number of pages written - this might legally be 0
1404  *                if xbzrle noticed the page was the same.
1405  *
1406  * @rs: current RAM state
1407  * @block: block that contains the page we want to send
1408  * @offset: offset inside the block for the page
1409  */
1410 static int ram_save_page(RAMState *rs, PageSearchStatus *pss)
1411 {
1412     int pages = -1;
1413     uint8_t *p;
1414     bool send_async = true;
1415     RAMBlock *block = pss->block;
1416     ram_addr_t offset = ((ram_addr_t)pss->page) << TARGET_PAGE_BITS;
1417     ram_addr_t current_addr = block->offset + offset;
1418
1419     p = block->host + offset;
1420     trace_ram_save_page(block->idstr, (uint64_t)offset, p);
1421
1422     XBZRLE_cache_lock();
1423     if (rs->xbzrle_enabled && !migration_in_postcopy()) {
1424         pages = save_xbzrle_page(rs, pss, &p, current_addr,
1425                                  block, offset);
1426         if (!rs->last_stage) {
1427             /* Can't send this cached data async, since the cache page
1428              * might get updated before it gets to the wire
1429              */
1430             send_async = false;
1431         }
1432     }
1433
1434     /* XBZRLE overflow or normal page */
1435     if (pages == -1) {
1436         pages = save_normal_page(pss, block, offset, p, send_async);
1437     }
1438
1439     XBZRLE_cache_unlock();
1440
1441     return pages;
1442 }
1443
1444 static int ram_save_multifd_page(QEMUFile *file, RAMBlock *block,
1445                                  ram_addr_t offset)
1446 {
1447     if (multifd_queue_page(file, block, offset) < 0) {
1448         return -1;
1449     }
1450     stat64_add(&mig_stats.normal_pages, 1);
1451
1452     return 1;
1453 }
1454
1455 static bool do_compress_ram_page(QEMUFile *f, z_stream *stream, RAMBlock *block,
1456                                  ram_addr_t offset, uint8_t *source_buf)
1457 {
1458     RAMState *rs = ram_state;
1459     PageSearchStatus *pss = &rs->pss[RAM_CHANNEL_PRECOPY];
1460     uint8_t *p = block->host + offset;
1461     int ret;
1462
1463     if (save_zero_page_to_file(pss, f, block, offset)) {
1464         return true;
1465     }
1466
1467     save_page_header(pss, f, block, offset | RAM_SAVE_FLAG_COMPRESS_PAGE);
1468
1469     /*
1470      * copy it to a internal buffer to avoid it being modified by VM
1471      * so that we can catch up the error during compression and
1472      * decompression
1473      */
1474     memcpy(source_buf, p, TARGET_PAGE_SIZE);
1475     ret = qemu_put_compression_data(f, stream, source_buf, TARGET_PAGE_SIZE);
1476     if (ret < 0) {
1477         qemu_file_set_error(migrate_get_current()->to_dst_file, ret);
1478         error_report("compressed data failed!");
1479     }
1480     return false;
1481 }
1482
1483 static void
1484 update_compress_thread_counts(const CompressParam *param, int bytes_xmit)
1485 {
1486     ram_transferred_add(bytes_xmit);
1487
1488     if (param->zero_page) {
1489         stat64_add(&mig_stats.zero_pages, 1);
1490         return;
1491     }
1492
1493     /* 8 means a header with RAM_SAVE_FLAG_CONTINUE. */
1494     compression_counters.compressed_size += bytes_xmit - 8;
1495     compression_counters.pages++;
1496 }
1497
1498 static bool save_page_use_compression(RAMState *rs);
1499
1500 static void flush_compressed_data(RAMState *rs)
1501 {
1502     MigrationState *ms = migrate_get_current();
1503     int idx, len, thread_count;
1504
1505     if (!save_page_use_compression(rs)) {
1506         return;
1507     }
1508     thread_count = migrate_compress_threads();
1509
1510     qemu_mutex_lock(&comp_done_lock);
1511     for (idx = 0; idx < thread_count; idx++) {
1512         while (!comp_param[idx].done) {
1513             qemu_cond_wait(&comp_done_cond, &comp_done_lock);
1514         }
1515     }
1516     qemu_mutex_unlock(&comp_done_lock);
1517
1518     for (idx = 0; idx < thread_count; idx++) {
1519         qemu_mutex_lock(&comp_param[idx].mutex);
1520         if (!comp_param[idx].quit) {
1521             len = qemu_put_qemu_file(ms->to_dst_file, comp_param[idx].file);
1522             /*
1523              * it's safe to fetch zero_page without holding comp_done_lock
1524              * as there is no further request submitted to the thread,
1525              * i.e, the thread should be waiting for a request at this point.
1526              */
1527             update_compress_thread_counts(&comp_param[idx], len);
1528         }
1529         qemu_mutex_unlock(&comp_param[idx].mutex);
1530     }
1531 }
1532
1533 static inline void set_compress_params(CompressParam *param, RAMBlock *block,
1534                                        ram_addr_t offset)
1535 {
1536     param->block = block;
1537     param->offset = offset;
1538 }
1539
1540 static int compress_page_with_multi_thread(RAMBlock *block, ram_addr_t offset)
1541 {
1542     int idx, thread_count, bytes_xmit = -1, pages = -1;
1543     bool wait = migrate_compress_wait_thread();
1544     MigrationState *ms = migrate_get_current();
1545
1546     thread_count = migrate_compress_threads();
1547     qemu_mutex_lock(&comp_done_lock);
1548 retry:
1549     for (idx = 0; idx < thread_count; idx++) {
1550         if (comp_param[idx].done) {
1551             comp_param[idx].done = false;
1552             bytes_xmit = qemu_put_qemu_file(ms->to_dst_file,
1553                                             comp_param[idx].file);
1554             qemu_mutex_lock(&comp_param[idx].mutex);
1555             set_compress_params(&comp_param[idx], block, offset);
1556             qemu_cond_signal(&comp_param[idx].cond);
1557             qemu_mutex_unlock(&comp_param[idx].mutex);
1558             pages = 1;
1559             update_compress_thread_counts(&comp_param[idx], bytes_xmit);
1560             break;
1561         }
1562     }
1563
1564     /*
1565      * wait for the free thread if the user specifies 'compress-wait-thread',
1566      * otherwise we will post the page out in the main thread as normal page.
1567      */
1568     if (pages < 0 && wait) {
1569         qemu_cond_wait(&comp_done_cond, &comp_done_lock);
1570         goto retry;
1571     }
1572     qemu_mutex_unlock(&comp_done_lock);
1573
1574     return pages;
1575 }
1576
1577 #define PAGE_ALL_CLEAN 0
1578 #define PAGE_TRY_AGAIN 1
1579 #define PAGE_DIRTY_FOUND 2
1580 /**
1581  * find_dirty_block: find the next dirty page and update any state
1582  * associated with the search process.
1583  *
1584  * Returns:
1585  *         <0: An error happened
1586  *         PAGE_ALL_CLEAN: no dirty page found, give up
1587  *         PAGE_TRY_AGAIN: no dirty page found, retry for next block
1588  *         PAGE_DIRTY_FOUND: dirty page found
1589  *
1590  * @rs: current RAM state
1591  * @pss: data about the state of the current dirty page scan
1592  * @again: set to false if the search has scanned the whole of RAM
1593  */
1594 static int find_dirty_block(RAMState *rs, PageSearchStatus *pss)
1595 {
1596     /* Update pss->page for the next dirty bit in ramblock */
1597     pss_find_next_dirty(pss);
1598
1599     if (pss->complete_round && pss->block == rs->last_seen_block &&
1600         pss->page >= rs->last_page) {
1601         /*
1602          * We've been once around the RAM and haven't found anything.
1603          * Give up.
1604          */
1605         return PAGE_ALL_CLEAN;
1606     }
1607     if (!offset_in_ramblock(pss->block,
1608                             ((ram_addr_t)pss->page) << TARGET_PAGE_BITS)) {
1609         /* Didn't find anything in this RAM Block */
1610         pss->page = 0;
1611         pss->block = QLIST_NEXT_RCU(pss->block, next);
1612         if (!pss->block) {
1613             if (!migrate_multifd_flush_after_each_section()) {
1614                 QEMUFile *f = rs->pss[RAM_CHANNEL_PRECOPY].pss_channel;
1615                 int ret = multifd_send_sync_main(f);
1616                 if (ret < 0) {
1617                     return ret;
1618                 }
1619                 qemu_put_be64(f, RAM_SAVE_FLAG_MULTIFD_FLUSH);
1620                 qemu_fflush(f);
1621             }
1622             /*
1623              * If memory migration starts over, we will meet a dirtied page
1624              * which may still exists in compression threads's ring, so we
1625              * should flush the compressed data to make sure the new page
1626              * is not overwritten by the old one in the destination.
1627              *
1628              * Also If xbzrle is on, stop using the data compression at this
1629              * point. In theory, xbzrle can do better than compression.
1630              */
1631             flush_compressed_data(rs);
1632
1633             /* Hit the end of the list */
1634             pss->block = QLIST_FIRST_RCU(&ram_list.blocks);
1635             /* Flag that we've looped */
1636             pss->complete_round = true;
1637             /* After the first round, enable XBZRLE. */
1638             if (migrate_xbzrle()) {
1639                 rs->xbzrle_enabled = true;
1640             }
1641         }
1642         /* Didn't find anything this time, but try again on the new block */
1643         return PAGE_TRY_AGAIN;
1644     } else {
1645         /* We've found something */
1646         return PAGE_DIRTY_FOUND;
1647     }
1648 }
1649
1650 /**
1651  * unqueue_page: gets a page of the queue
1652  *
1653  * Helper for 'get_queued_page' - gets a page off the queue
1654  *
1655  * Returns the block of the page (or NULL if none available)
1656  *
1657  * @rs: current RAM state
1658  * @offset: used to return the offset within the RAMBlock
1659  */
1660 static RAMBlock *unqueue_page(RAMState *rs, ram_addr_t *offset)
1661 {
1662     struct RAMSrcPageRequest *entry;
1663     RAMBlock *block = NULL;
1664
1665     if (!postcopy_has_request(rs)) {
1666         return NULL;
1667     }
1668
1669     QEMU_LOCK_GUARD(&rs->src_page_req_mutex);
1670
1671     /*
1672      * This should _never_ change even after we take the lock, because no one
1673      * should be taking anything off the request list other than us.
1674      */
1675     assert(postcopy_has_request(rs));
1676
1677     entry = QSIMPLEQ_FIRST(&rs->src_page_requests);
1678     block = entry->rb;
1679     *offset = entry->offset;
1680
1681     if (entry->len > TARGET_PAGE_SIZE) {
1682         entry->len -= TARGET_PAGE_SIZE;
1683         entry->offset += TARGET_PAGE_SIZE;
1684     } else {
1685         memory_region_unref(block->mr);
1686         QSIMPLEQ_REMOVE_HEAD(&rs->src_page_requests, next_req);
1687         g_free(entry);
1688         migration_consume_urgent_request();
1689     }
1690
1691     return block;
1692 }
1693
1694 #if defined(__linux__)
1695 /**
1696  * poll_fault_page: try to get next UFFD write fault page and, if pending fault
1697  *   is found, return RAM block pointer and page offset
1698  *
1699  * Returns pointer to the RAMBlock containing faulting page,
1700  *   NULL if no write faults are pending
1701  *
1702  * @rs: current RAM state
1703  * @offset: page offset from the beginning of the block
1704  */
1705 static RAMBlock *poll_fault_page(RAMState *rs, ram_addr_t *offset)
1706 {
1707     struct uffd_msg uffd_msg;
1708     void *page_address;
1709     RAMBlock *block;
1710     int res;
1711
1712     if (!migrate_background_snapshot()) {
1713         return NULL;
1714     }
1715
1716     res = uffd_read_events(rs->uffdio_fd, &uffd_msg, 1);
1717     if (res <= 0) {
1718         return NULL;
1719     }
1720
1721     page_address = (void *)(uintptr_t) uffd_msg.arg.pagefault.address;
1722     block = qemu_ram_block_from_host(page_address, false, offset);
1723     assert(block && (block->flags & RAM_UF_WRITEPROTECT) != 0);
1724     return block;
1725 }
1726
1727 /**
1728  * ram_save_release_protection: release UFFD write protection after
1729  *   a range of pages has been saved
1730  *
1731  * @rs: current RAM state
1732  * @pss: page-search-status structure
1733  * @start_page: index of the first page in the range relative to pss->block
1734  *
1735  * Returns 0 on success, negative value in case of an error
1736 */
1737 static int ram_save_release_protection(RAMState *rs, PageSearchStatus *pss,
1738         unsigned long start_page)
1739 {
1740     int res = 0;
1741
1742     /* Check if page is from UFFD-managed region. */
1743     if (pss->block->flags & RAM_UF_WRITEPROTECT) {
1744         void *page_address = pss->block->host + (start_page << TARGET_PAGE_BITS);
1745         uint64_t run_length = (pss->page - start_page) << TARGET_PAGE_BITS;
1746
1747         /* Flush async buffers before un-protect. */
1748         qemu_fflush(pss->pss_channel);
1749         /* Un-protect memory range. */
1750         res = uffd_change_protection(rs->uffdio_fd, page_address, run_length,
1751                 false, false);
1752     }
1753
1754     return res;
1755 }
1756
1757 /* ram_write_tracking_available: check if kernel supports required UFFD features
1758  *
1759  * Returns true if supports, false otherwise
1760  */
1761 bool ram_write_tracking_available(void)
1762 {
1763     uint64_t uffd_features;
1764     int res;
1765
1766     res = uffd_query_features(&uffd_features);
1767     return (res == 0 &&
1768             (uffd_features & UFFD_FEATURE_PAGEFAULT_FLAG_WP) != 0);
1769 }
1770
1771 /* ram_write_tracking_compatible: check if guest configuration is
1772  *   compatible with 'write-tracking'
1773  *
1774  * Returns true if compatible, false otherwise
1775  */
1776 bool ram_write_tracking_compatible(void)
1777 {
1778     const uint64_t uffd_ioctls_mask = BIT(_UFFDIO_WRITEPROTECT);
1779     int uffd_fd;
1780     RAMBlock *block;
1781     bool ret = false;
1782
1783     /* Open UFFD file descriptor */
1784     uffd_fd = uffd_create_fd(UFFD_FEATURE_PAGEFAULT_FLAG_WP, false);
1785     if (uffd_fd < 0) {
1786         return false;
1787     }
1788
1789     RCU_READ_LOCK_GUARD();
1790
1791     RAMBLOCK_FOREACH_NOT_IGNORED(block) {
1792         uint64_t uffd_ioctls;
1793
1794         /* Nothing to do with read-only and MMIO-writable regions */
1795         if (block->mr->readonly || block->mr->rom_device) {
1796             continue;
1797         }
1798         /* Try to register block memory via UFFD-IO to track writes */
1799         if (uffd_register_memory(uffd_fd, block->host, block->max_length,
1800                 UFFDIO_REGISTER_MODE_WP, &uffd_ioctls)) {
1801             goto out;
1802         }
1803         if ((uffd_ioctls & uffd_ioctls_mask) != uffd_ioctls_mask) {
1804             goto out;
1805         }
1806     }
1807     ret = true;
1808
1809 out:
1810     uffd_close_fd(uffd_fd);
1811     return ret;
1812 }
1813
1814 static inline void populate_read_range(RAMBlock *block, ram_addr_t offset,
1815                                        ram_addr_t size)
1816 {
1817     const ram_addr_t end = offset + size;
1818
1819     /*
1820      * We read one byte of each page; this will preallocate page tables if
1821      * required and populate the shared zeropage on MAP_PRIVATE anonymous memory
1822      * where no page was populated yet. This might require adaption when
1823      * supporting other mappings, like shmem.
1824      */
1825     for (; offset < end; offset += block->page_size) {
1826         char tmp = *((char *)block->host + offset);
1827
1828         /* Don't optimize the read out */
1829         asm volatile("" : "+r" (tmp));
1830     }
1831 }
1832
1833 static inline int populate_read_section(MemoryRegionSection *section,
1834                                         void *opaque)
1835 {
1836     const hwaddr size = int128_get64(section->size);
1837     hwaddr offset = section->offset_within_region;
1838     RAMBlock *block = section->mr->ram_block;
1839
1840     populate_read_range(block, offset, size);
1841     return 0;
1842 }
1843
1844 /*
1845  * ram_block_populate_read: preallocate page tables and populate pages in the
1846  *   RAM block by reading a byte of each page.
1847  *
1848  * Since it's solely used for userfault_fd WP feature, here we just
1849  *   hardcode page size to qemu_real_host_page_size.
1850  *
1851  * @block: RAM block to populate
1852  */
1853 static void ram_block_populate_read(RAMBlock *rb)
1854 {
1855     /*
1856      * Skip populating all pages that fall into a discarded range as managed by
1857      * a RamDiscardManager responsible for the mapped memory region of the
1858      * RAMBlock. Such discarded ("logically unplugged") parts of a RAMBlock
1859      * must not get populated automatically. We don't have to track
1860      * modifications via userfaultfd WP reliably, because these pages will
1861      * not be part of the migration stream either way -- see
1862      * ramblock_dirty_bitmap_exclude_discarded_pages().
1863      *
1864      * Note: The result is only stable while migrating (precopy/postcopy).
1865      */
1866     if (rb->mr && memory_region_has_ram_discard_manager(rb->mr)) {
1867         RamDiscardManager *rdm = memory_region_get_ram_discard_manager(rb->mr);
1868         MemoryRegionSection section = {
1869             .mr = rb->mr,
1870             .offset_within_region = 0,
1871             .size = rb->mr->size,
1872         };
1873
1874         ram_discard_manager_replay_populated(rdm, &section,
1875                                              populate_read_section, NULL);
1876     } else {
1877         populate_read_range(rb, 0, rb->used_length);
1878     }
1879 }
1880
1881 /*
1882  * ram_write_tracking_prepare: prepare for UFFD-WP memory tracking
1883  */
1884 void ram_write_tracking_prepare(void)
1885 {
1886     RAMBlock *block;
1887
1888     RCU_READ_LOCK_GUARD();
1889
1890     RAMBLOCK_FOREACH_NOT_IGNORED(block) {
1891         /* Nothing to do with read-only and MMIO-writable regions */
1892         if (block->mr->readonly || block->mr->rom_device) {
1893             continue;
1894         }
1895
1896         /*
1897          * Populate pages of the RAM block before enabling userfault_fd
1898          * write protection.
1899          *
1900          * This stage is required since ioctl(UFFDIO_WRITEPROTECT) with
1901          * UFFDIO_WRITEPROTECT_MODE_WP mode setting would silently skip
1902          * pages with pte_none() entries in page table.
1903          */
1904         ram_block_populate_read(block);
1905     }
1906 }
1907
1908 static inline int uffd_protect_section(MemoryRegionSection *section,
1909                                        void *opaque)
1910 {
1911     const hwaddr size = int128_get64(section->size);
1912     const hwaddr offset = section->offset_within_region;
1913     RAMBlock *rb = section->mr->ram_block;
1914     int uffd_fd = (uintptr_t)opaque;
1915
1916     return uffd_change_protection(uffd_fd, rb->host + offset, size, true,
1917                                   false);
1918 }
1919
1920 static int ram_block_uffd_protect(RAMBlock *rb, int uffd_fd)
1921 {
1922     assert(rb->flags & RAM_UF_WRITEPROTECT);
1923
1924     /* See ram_block_populate_read() */
1925     if (rb->mr && memory_region_has_ram_discard_manager(rb->mr)) {
1926         RamDiscardManager *rdm = memory_region_get_ram_discard_manager(rb->mr);
1927         MemoryRegionSection section = {
1928             .mr = rb->mr,
1929             .offset_within_region = 0,
1930             .size = rb->mr->size,
1931         };
1932
1933         return ram_discard_manager_replay_populated(rdm, &section,
1934                                                     uffd_protect_section,
1935                                                     (void *)(uintptr_t)uffd_fd);
1936     }
1937     return uffd_change_protection(uffd_fd, rb->host,
1938                                   rb->used_length, true, false);
1939 }
1940
1941 /*
1942  * ram_write_tracking_start: start UFFD-WP memory tracking
1943  *
1944  * Returns 0 for success or negative value in case of error
1945  */
1946 int ram_write_tracking_start(void)
1947 {
1948     int uffd_fd;
1949     RAMState *rs = ram_state;
1950     RAMBlock *block;
1951
1952     /* Open UFFD file descriptor */
1953     uffd_fd = uffd_create_fd(UFFD_FEATURE_PAGEFAULT_FLAG_WP, true);
1954     if (uffd_fd < 0) {
1955         return uffd_fd;
1956     }
1957     rs->uffdio_fd = uffd_fd;
1958
1959     RCU_READ_LOCK_GUARD();
1960
1961     RAMBLOCK_FOREACH_NOT_IGNORED(block) {
1962         /* Nothing to do with read-only and MMIO-writable regions */
1963         if (block->mr->readonly || block->mr->rom_device) {
1964             continue;
1965         }
1966
1967         /* Register block memory with UFFD to track writes */
1968         if (uffd_register_memory(rs->uffdio_fd, block->host,
1969                 block->max_length, UFFDIO_REGISTER_MODE_WP, NULL)) {
1970             goto fail;
1971         }
1972         block->flags |= RAM_UF_WRITEPROTECT;
1973         memory_region_ref(block->mr);
1974
1975         /* Apply UFFD write protection to the block memory range */
1976         if (ram_block_uffd_protect(block, uffd_fd)) {
1977             goto fail;
1978         }
1979
1980         trace_ram_write_tracking_ramblock_start(block->idstr, block->page_size,
1981                 block->host, block->max_length);
1982     }
1983
1984     return 0;
1985
1986 fail:
1987     error_report("ram_write_tracking_start() failed: restoring initial memory state");
1988
1989     RAMBLOCK_FOREACH_NOT_IGNORED(block) {
1990         if ((block->flags & RAM_UF_WRITEPROTECT) == 0) {
1991             continue;
1992         }
1993         uffd_unregister_memory(rs->uffdio_fd, block->host, block->max_length);
1994         /* Cleanup flags and remove reference */
1995         block->flags &= ~RAM_UF_WRITEPROTECT;
1996         memory_region_unref(block->mr);
1997     }
1998
1999     uffd_close_fd(uffd_fd);
2000     rs->uffdio_fd = -1;
2001     return -1;
2002 }
2003
2004 /**
2005  * ram_write_tracking_stop: stop UFFD-WP memory tracking and remove protection
2006  */
2007 void ram_write_tracking_stop(void)
2008 {
2009     RAMState *rs = ram_state;
2010     RAMBlock *block;
2011
2012     RCU_READ_LOCK_GUARD();
2013
2014     RAMBLOCK_FOREACH_NOT_IGNORED(block) {
2015         if ((block->flags & RAM_UF_WRITEPROTECT) == 0) {
2016             continue;
2017         }
2018         uffd_unregister_memory(rs->uffdio_fd, block->host, block->max_length);
2019
2020         trace_ram_write_tracking_ramblock_stop(block->idstr, block->page_size,
2021                 block->host, block->max_length);
2022
2023         /* Cleanup flags and remove reference */
2024         block->flags &= ~RAM_UF_WRITEPROTECT;
2025         memory_region_unref(block->mr);
2026     }
2027
2028     /* Finally close UFFD file descriptor */
2029     uffd_close_fd(rs->uffdio_fd);
2030     rs->uffdio_fd = -1;
2031 }
2032
2033 #else
2034 /* No target OS support, stubs just fail or ignore */
2035
2036 static RAMBlock *poll_fault_page(RAMState *rs, ram_addr_t *offset)
2037 {
2038     (void) rs;
2039     (void) offset;
2040
2041     return NULL;
2042 }
2043
2044 static int ram_save_release_protection(RAMState *rs, PageSearchStatus *pss,
2045         unsigned long start_page)
2046 {
2047     (void) rs;
2048     (void) pss;
2049     (void) start_page;
2050
2051     return 0;
2052 }
2053
2054 bool ram_write_tracking_available(void)
2055 {
2056     return false;
2057 }
2058
2059 bool ram_write_tracking_compatible(void)
2060 {
2061     assert(0);
2062     return false;
2063 }
2064
2065 int ram_write_tracking_start(void)
2066 {
2067     assert(0);
2068     return -1;
2069 }
2070
2071 void ram_write_tracking_stop(void)
2072 {
2073     assert(0);
2074 }
2075 #endif /* defined(__linux__) */
2076
2077 /**
2078  * get_queued_page: unqueue a page from the postcopy requests
2079  *
2080  * Skips pages that are already sent (!dirty)
2081  *
2082  * Returns true if a queued page is found
2083  *
2084  * @rs: current RAM state
2085  * @pss: data about the state of the current dirty page scan
2086  */
2087 static bool get_queued_page(RAMState *rs, PageSearchStatus *pss)
2088 {
2089     RAMBlock  *block;
2090     ram_addr_t offset;
2091     bool dirty;
2092
2093     do {
2094         block = unqueue_page(rs, &offset);
2095         /*
2096          * We're sending this page, and since it's postcopy nothing else
2097          * will dirty it, and we must make sure it doesn't get sent again
2098          * even if this queue request was received after the background
2099          * search already sent it.
2100          */
2101         if (block) {
2102             unsigned long page;
2103
2104             page = offset >> TARGET_PAGE_BITS;
2105             dirty = test_bit(page, block->bmap);
2106             if (!dirty) {
2107                 trace_get_queued_page_not_dirty(block->idstr, (uint64_t)offset,
2108                                                 page);
2109             } else {
2110                 trace_get_queued_page(block->idstr, (uint64_t)offset, page);
2111             }
2112         }
2113
2114     } while (block && !dirty);
2115
2116     if (!block) {
2117         /*
2118          * Poll write faults too if background snapshot is enabled; that's
2119          * when we have vcpus got blocked by the write protected pages.
2120          */
2121         block = poll_fault_page(rs, &offset);
2122     }
2123
2124     if (block) {
2125         /*
2126          * We want the background search to continue from the queued page
2127          * since the guest is likely to want other pages near to the page
2128          * it just requested.
2129          */
2130         pss->block = block;
2131         pss->page = offset >> TARGET_PAGE_BITS;
2132
2133         /*
2134          * This unqueued page would break the "one round" check, even is
2135          * really rare.
2136          */
2137         pss->complete_round = false;
2138     }
2139
2140     return !!block;
2141 }
2142
2143 /**
2144  * migration_page_queue_free: drop any remaining pages in the ram
2145  * request queue
2146  *
2147  * It should be empty at the end anyway, but in error cases there may
2148  * be some left.  in case that there is any page left, we drop it.
2149  *
2150  */
2151 static void migration_page_queue_free(RAMState *rs)
2152 {
2153     struct RAMSrcPageRequest *mspr, *next_mspr;
2154     /* This queue generally should be empty - but in the case of a failed
2155      * migration might have some droppings in.
2156      */
2157     RCU_READ_LOCK_GUARD();
2158     QSIMPLEQ_FOREACH_SAFE(mspr, &rs->src_page_requests, next_req, next_mspr) {
2159         memory_region_unref(mspr->rb->mr);
2160         QSIMPLEQ_REMOVE_HEAD(&rs->src_page_requests, next_req);
2161         g_free(mspr);
2162     }
2163 }
2164
2165 /**
2166  * ram_save_queue_pages: queue the page for transmission
2167  *
2168  * A request from postcopy destination for example.
2169  *
2170  * Returns zero on success or negative on error
2171  *
2172  * @rbname: Name of the RAMBLock of the request. NULL means the
2173  *          same that last one.
2174  * @start: starting address from the start of the RAMBlock
2175  * @len: length (in bytes) to send
2176  */
2177 int ram_save_queue_pages(const char *rbname, ram_addr_t start, ram_addr_t len)
2178 {
2179     RAMBlock *ramblock;
2180     RAMState *rs = ram_state;
2181
2182     stat64_add(&mig_stats.postcopy_requests, 1);
2183     RCU_READ_LOCK_GUARD();
2184
2185     if (!rbname) {
2186         /* Reuse last RAMBlock */
2187         ramblock = rs->last_req_rb;
2188
2189         if (!ramblock) {
2190             /*
2191              * Shouldn't happen, we can't reuse the last RAMBlock if
2192              * it's the 1st request.
2193              */
2194             error_report("ram_save_queue_pages no previous block");
2195             return -1;
2196         }
2197     } else {
2198         ramblock = qemu_ram_block_by_name(rbname);
2199
2200         if (!ramblock) {
2201             /* We shouldn't be asked for a non-existent RAMBlock */
2202             error_report("ram_save_queue_pages no block '%s'", rbname);
2203             return -1;
2204         }
2205         rs->last_req_rb = ramblock;
2206     }
2207     trace_ram_save_queue_pages(ramblock->idstr, start, len);
2208     if (!offset_in_ramblock(ramblock, start + len - 1)) {
2209         error_report("%s request overrun start=" RAM_ADDR_FMT " len="
2210                      RAM_ADDR_FMT " blocklen=" RAM_ADDR_FMT,
2211                      __func__, start, len, ramblock->used_length);
2212         return -1;
2213     }
2214
2215     /*
2216      * When with postcopy preempt, we send back the page directly in the
2217      * rp-return thread.
2218      */
2219     if (postcopy_preempt_active()) {
2220         ram_addr_t page_start = start >> TARGET_PAGE_BITS;
2221         size_t page_size = qemu_ram_pagesize(ramblock);
2222         PageSearchStatus *pss = &ram_state->pss[RAM_CHANNEL_POSTCOPY];
2223         int ret = 0;
2224
2225         qemu_mutex_lock(&rs->bitmap_mutex);
2226
2227         pss_init(pss, ramblock, page_start);
2228         /*
2229          * Always use the preempt channel, and make sure it's there.  It's
2230          * safe to access without lock, because when rp-thread is running
2231          * we should be the only one who operates on the qemufile
2232          */
2233         pss->pss_channel = migrate_get_current()->postcopy_qemufile_src;
2234         assert(pss->pss_channel);
2235
2236         /*
2237          * It must be either one or multiple of host page size.  Just
2238          * assert; if something wrong we're mostly split brain anyway.
2239          */
2240         assert(len % page_size == 0);
2241         while (len) {
2242             if (ram_save_host_page_urgent(pss)) {
2243                 error_report("%s: ram_save_host_page_urgent() failed: "
2244                              "ramblock=%s, start_addr=0x"RAM_ADDR_FMT,
2245                              __func__, ramblock->idstr, start);
2246                 ret = -1;
2247                 break;
2248             }
2249             /*
2250              * NOTE: after ram_save_host_page_urgent() succeeded, pss->page
2251              * will automatically be moved and point to the next host page
2252              * we're going to send, so no need to update here.
2253              *
2254              * Normally QEMU never sends >1 host page in requests, so
2255              * logically we don't even need that as the loop should only
2256              * run once, but just to be consistent.
2257              */
2258             len -= page_size;
2259         };
2260         qemu_mutex_unlock(&rs->bitmap_mutex);
2261
2262         return ret;
2263     }
2264
2265     struct RAMSrcPageRequest *new_entry =
2266         g_new0(struct RAMSrcPageRequest, 1);
2267     new_entry->rb = ramblock;
2268     new_entry->offset = start;
2269     new_entry->len = len;
2270
2271     memory_region_ref(ramblock->mr);
2272     qemu_mutex_lock(&rs->src_page_req_mutex);
2273     QSIMPLEQ_INSERT_TAIL(&rs->src_page_requests, new_entry, next_req);
2274     migration_make_urgent_request();
2275     qemu_mutex_unlock(&rs->src_page_req_mutex);
2276
2277     return 0;
2278 }
2279
2280 static bool save_page_use_compression(RAMState *rs)
2281 {
2282     if (!migrate_compress()) {
2283         return false;
2284     }
2285
2286     /*
2287      * If xbzrle is enabled (e.g., after first round of migration), stop
2288      * using the data compression. In theory, xbzrle can do better than
2289      * compression.
2290      */
2291     if (rs->xbzrle_enabled) {
2292         return false;
2293     }
2294
2295     return true;
2296 }
2297
2298 /*
2299  * try to compress the page before posting it out, return true if the page
2300  * has been properly handled by compression, otherwise needs other
2301  * paths to handle it
2302  */
2303 static bool save_compress_page(RAMState *rs, PageSearchStatus *pss,
2304                                RAMBlock *block, ram_addr_t offset)
2305 {
2306     if (!save_page_use_compression(rs)) {
2307         return false;
2308     }
2309
2310     /*
2311      * When starting the process of a new block, the first page of
2312      * the block should be sent out before other pages in the same
2313      * block, and all the pages in last block should have been sent
2314      * out, keeping this order is important, because the 'cont' flag
2315      * is used to avoid resending the block name.
2316      *
2317      * We post the fist page as normal page as compression will take
2318      * much CPU resource.
2319      */
2320     if (block != pss->last_sent_block) {
2321         flush_compressed_data(rs);
2322         return false;
2323     }
2324
2325     if (compress_page_with_multi_thread(block, offset) > 0) {
2326         return true;
2327     }
2328
2329     compression_counters.busy++;
2330     return false;
2331 }
2332
2333 /**
2334  * ram_save_target_page_legacy: save one target page
2335  *
2336  * Returns the number of pages written
2337  *
2338  * @rs: current RAM state
2339  * @pss: data about the page we want to send
2340  */
2341 static int ram_save_target_page_legacy(RAMState *rs, PageSearchStatus *pss)
2342 {
2343     RAMBlock *block = pss->block;
2344     ram_addr_t offset = ((ram_addr_t)pss->page) << TARGET_PAGE_BITS;
2345     int res;
2346
2347     if (control_save_page(pss, block, offset, &res)) {
2348         return res;
2349     }
2350
2351     if (save_compress_page(rs, pss, block, offset)) {
2352         return 1;
2353     }
2354
2355     res = save_zero_page(pss, pss->pss_channel, block, offset);
2356     if (res > 0) {
2357         /* Must let xbzrle know, otherwise a previous (now 0'd) cached
2358          * page would be stale
2359          */
2360         if (rs->xbzrle_enabled) {
2361             XBZRLE_cache_lock();
2362             xbzrle_cache_zero_page(rs, block->offset + offset);
2363             XBZRLE_cache_unlock();
2364         }
2365         return res;
2366     }
2367
2368     /*
2369      * Do not use multifd in postcopy as one whole host page should be
2370      * placed.  Meanwhile postcopy requires atomic update of pages, so even
2371      * if host page size == guest page size the dest guest during run may
2372      * still see partially copied pages which is data corruption.
2373      */
2374     if (migrate_multifd() && !migration_in_postcopy()) {
2375         return ram_save_multifd_page(pss->pss_channel, block, offset);
2376     }
2377
2378     return ram_save_page(rs, pss);
2379 }
2380
2381 /* Should be called before sending a host page */
2382 static void pss_host_page_prepare(PageSearchStatus *pss)
2383 {
2384     /* How many guest pages are there in one host page? */
2385     size_t guest_pfns = qemu_ram_pagesize(pss->block) >> TARGET_PAGE_BITS;
2386
2387     pss->host_page_sending = true;
2388     if (guest_pfns <= 1) {
2389         /*
2390          * This covers both when guest psize == host psize, or when guest
2391          * has larger psize than the host (guest_pfns==0).
2392          *
2393          * For the latter, we always send one whole guest page per
2394          * iteration of the host page (example: an Alpha VM on x86 host
2395          * will have guest psize 8K while host psize 4K).
2396          */
2397         pss->host_page_start = pss->page;
2398         pss->host_page_end = pss->page + 1;
2399     } else {
2400         /*
2401          * The host page spans over multiple guest pages, we send them
2402          * within the same host page iteration.
2403          */
2404         pss->host_page_start = ROUND_DOWN(pss->page, guest_pfns);
2405         pss->host_page_end = ROUND_UP(pss->page + 1, guest_pfns);
2406     }
2407 }
2408
2409 /*
2410  * Whether the page pointed by PSS is within the host page being sent.
2411  * Must be called after a previous pss_host_page_prepare().
2412  */
2413 static bool pss_within_range(PageSearchStatus *pss)
2414 {
2415     ram_addr_t ram_addr;
2416
2417     assert(pss->host_page_sending);
2418
2419     /* Over host-page boundary? */
2420     if (pss->page >= pss->host_page_end) {
2421         return false;
2422     }
2423
2424     ram_addr = ((ram_addr_t)pss->page) << TARGET_PAGE_BITS;
2425
2426     return offset_in_ramblock(pss->block, ram_addr);
2427 }
2428
2429 static void pss_host_page_finish(PageSearchStatus *pss)
2430 {
2431     pss->host_page_sending = false;
2432     /* This is not needed, but just to reset it */
2433     pss->host_page_start = pss->host_page_end = 0;
2434 }
2435
2436 /*
2437  * Send an urgent host page specified by `pss'.  Need to be called with
2438  * bitmap_mutex held.
2439  *
2440  * Returns 0 if save host page succeeded, false otherwise.
2441  */
2442 static int ram_save_host_page_urgent(PageSearchStatus *pss)
2443 {
2444     bool page_dirty, sent = false;
2445     RAMState *rs = ram_state;
2446     int ret = 0;
2447
2448     trace_postcopy_preempt_send_host_page(pss->block->idstr, pss->page);
2449     pss_host_page_prepare(pss);
2450
2451     /*
2452      * If precopy is sending the same page, let it be done in precopy, or
2453      * we could send the same page in two channels and none of them will
2454      * receive the whole page.
2455      */
2456     if (pss_overlap(pss, &ram_state->pss[RAM_CHANNEL_PRECOPY])) {
2457         trace_postcopy_preempt_hit(pss->block->idstr,
2458                                    pss->page << TARGET_PAGE_BITS);
2459         return 0;
2460     }
2461
2462     do {
2463         page_dirty = migration_bitmap_clear_dirty(rs, pss->block, pss->page);
2464
2465         if (page_dirty) {
2466             /* Be strict to return code; it must be 1, or what else? */
2467             if (migration_ops->ram_save_target_page(rs, pss) != 1) {
2468                 error_report_once("%s: ram_save_target_page failed", __func__);
2469                 ret = -1;
2470                 goto out;
2471             }
2472             sent = true;
2473         }
2474         pss_find_next_dirty(pss);
2475     } while (pss_within_range(pss));
2476 out:
2477     pss_host_page_finish(pss);
2478     /* For urgent requests, flush immediately if sent */
2479     if (sent) {
2480         qemu_fflush(pss->pss_channel);
2481     }
2482     return ret;
2483 }
2484
2485 /**
2486  * ram_save_host_page: save a whole host page
2487  *
2488  * Starting at *offset send pages up to the end of the current host
2489  * page. It's valid for the initial offset to point into the middle of
2490  * a host page in which case the remainder of the hostpage is sent.
2491  * Only dirty target pages are sent. Note that the host page size may
2492  * be a huge page for this block.
2493  *
2494  * The saving stops at the boundary of the used_length of the block
2495  * if the RAMBlock isn't a multiple of the host page size.
2496  *
2497  * The caller must be with ram_state.bitmap_mutex held to call this
2498  * function.  Note that this function can temporarily release the lock, but
2499  * when the function is returned it'll make sure the lock is still held.
2500  *
2501  * Returns the number of pages written or negative on error
2502  *
2503  * @rs: current RAM state
2504  * @pss: data about the page we want to send
2505  */
2506 static int ram_save_host_page(RAMState *rs, PageSearchStatus *pss)
2507 {
2508     bool page_dirty, preempt_active = postcopy_preempt_active();
2509     int tmppages, pages = 0;
2510     size_t pagesize_bits =
2511         qemu_ram_pagesize(pss->block) >> TARGET_PAGE_BITS;
2512     unsigned long start_page = pss->page;
2513     int res;
2514
2515     if (ramblock_is_ignored(pss->block)) {
2516         error_report("block %s should not be migrated !", pss->block->idstr);
2517         return 0;
2518     }
2519
2520     /* Update host page boundary information */
2521     pss_host_page_prepare(pss);
2522
2523     do {
2524         page_dirty = migration_bitmap_clear_dirty(rs, pss->block, pss->page);
2525
2526         /* Check the pages is dirty and if it is send it */
2527         if (page_dirty) {
2528             /*
2529              * Properly yield the lock only in postcopy preempt mode
2530              * because both migration thread and rp-return thread can
2531              * operate on the bitmaps.
2532              */
2533             if (preempt_active) {
2534                 qemu_mutex_unlock(&rs->bitmap_mutex);
2535             }
2536             tmppages = migration_ops->ram_save_target_page(rs, pss);
2537             if (tmppages >= 0) {
2538                 pages += tmppages;
2539                 /*
2540                  * Allow rate limiting to happen in the middle of huge pages if
2541                  * something is sent in the current iteration.
2542                  */
2543                 if (pagesize_bits > 1 && tmppages > 0) {
2544                     migration_rate_limit();
2545                 }
2546             }
2547             if (preempt_active) {
2548                 qemu_mutex_lock(&rs->bitmap_mutex);
2549             }
2550         } else {
2551             tmppages = 0;
2552         }
2553
2554         if (tmppages < 0) {
2555             pss_host_page_finish(pss);
2556             return tmppages;
2557         }
2558
2559         pss_find_next_dirty(pss);
2560     } while (pss_within_range(pss));
2561
2562     pss_host_page_finish(pss);
2563
2564     res = ram_save_release_protection(rs, pss, start_page);
2565     return (res < 0 ? res : pages);
2566 }
2567
2568 /**
2569  * ram_find_and_save_block: finds a dirty page and sends it to f
2570  *
2571  * Called within an RCU critical section.
2572  *
2573  * Returns the number of pages written where zero means no dirty pages,
2574  * or negative on error
2575  *
2576  * @rs: current RAM state
2577  *
2578  * On systems where host-page-size > target-page-size it will send all the
2579  * pages in a host page that are dirty.
2580  */
2581 static int ram_find_and_save_block(RAMState *rs)
2582 {
2583     PageSearchStatus *pss = &rs->pss[RAM_CHANNEL_PRECOPY];
2584     int pages = 0;
2585
2586     /* No dirty page as there is zero RAM */
2587     if (!rs->ram_bytes_total) {
2588         return pages;
2589     }
2590
2591     /*
2592      * Always keep last_seen_block/last_page valid during this procedure,
2593      * because find_dirty_block() relies on these values (e.g., we compare
2594      * last_seen_block with pss.block to see whether we searched all the
2595      * ramblocks) to detect the completion of migration.  Having NULL value
2596      * of last_seen_block can conditionally cause below loop to run forever.
2597      */
2598     if (!rs->last_seen_block) {
2599         rs->last_seen_block = QLIST_FIRST_RCU(&ram_list.blocks);
2600         rs->last_page = 0;
2601     }
2602
2603     pss_init(pss, rs->last_seen_block, rs->last_page);
2604
2605     while (true){
2606         if (!get_queued_page(rs, pss)) {
2607             /* priority queue empty, so just search for something dirty */
2608             int res = find_dirty_block(rs, pss);
2609             if (res != PAGE_DIRTY_FOUND) {
2610                 if (res == PAGE_ALL_CLEAN) {
2611                     break;
2612                 } else if (res == PAGE_TRY_AGAIN) {
2613                     continue;
2614                 } else if (res < 0) {
2615                     pages = res;
2616                     break;
2617                 }
2618             }
2619         }
2620         pages = ram_save_host_page(rs, pss);
2621         if (pages) {
2622             break;
2623         }
2624     }
2625
2626     rs->last_seen_block = pss->block;
2627     rs->last_page = pss->page;
2628
2629     return pages;
2630 }
2631
2632 void acct_update_position(QEMUFile *f, size_t size)
2633 {
2634     uint64_t pages = size / TARGET_PAGE_SIZE;
2635
2636     stat64_add(&mig_stats.normal_pages, pages);
2637     ram_transferred_add(size);
2638     qemu_file_credit_transfer(f, size);
2639 }
2640
2641 static uint64_t ram_bytes_total_with_ignored(void)
2642 {
2643     RAMBlock *block;
2644     uint64_t total = 0;
2645
2646     RCU_READ_LOCK_GUARD();
2647
2648     RAMBLOCK_FOREACH_MIGRATABLE(block) {
2649         total += block->used_length;
2650     }
2651     return total;
2652 }
2653
2654 uint64_t ram_bytes_total(void)
2655 {
2656     RAMBlock *block;
2657     uint64_t total = 0;
2658
2659     RCU_READ_LOCK_GUARD();
2660
2661     RAMBLOCK_FOREACH_NOT_IGNORED(block) {
2662         total += block->used_length;
2663     }
2664     return total;
2665 }
2666
2667 static void xbzrle_load_setup(void)
2668 {
2669     XBZRLE.decoded_buf = g_malloc(TARGET_PAGE_SIZE);
2670 }
2671
2672 static void xbzrle_load_cleanup(void)
2673 {
2674     g_free(XBZRLE.decoded_buf);
2675     XBZRLE.decoded_buf = NULL;
2676 }
2677
2678 static void ram_state_cleanup(RAMState **rsp)
2679 {
2680     if (*rsp) {
2681         migration_page_queue_free(*rsp);
2682         qemu_mutex_destroy(&(*rsp)->bitmap_mutex);
2683         qemu_mutex_destroy(&(*rsp)->src_page_req_mutex);
2684         g_free(*rsp);
2685         *rsp = NULL;
2686     }
2687 }
2688
2689 static void xbzrle_cleanup(void)
2690 {
2691     XBZRLE_cache_lock();
2692     if (XBZRLE.cache) {
2693         cache_fini(XBZRLE.cache);
2694         g_free(XBZRLE.encoded_buf);
2695         g_free(XBZRLE.current_buf);
2696         g_free(XBZRLE.zero_target_page);
2697         XBZRLE.cache = NULL;
2698         XBZRLE.encoded_buf = NULL;
2699         XBZRLE.current_buf = NULL;
2700         XBZRLE.zero_target_page = NULL;
2701     }
2702     XBZRLE_cache_unlock();
2703 }
2704
2705 static void ram_save_cleanup(void *opaque)
2706 {
2707     RAMState **rsp = opaque;
2708     RAMBlock *block;
2709
2710     /* We don't use dirty log with background snapshots */
2711     if (!migrate_background_snapshot()) {
2712         /* caller have hold iothread lock or is in a bh, so there is
2713          * no writing race against the migration bitmap
2714          */
2715         if (global_dirty_tracking & GLOBAL_DIRTY_MIGRATION) {
2716             /*
2717              * do not stop dirty log without starting it, since
2718              * memory_global_dirty_log_stop will assert that
2719              * memory_global_dirty_log_start/stop used in pairs
2720              */
2721             memory_global_dirty_log_stop(GLOBAL_DIRTY_MIGRATION);
2722         }
2723     }
2724
2725     RAMBLOCK_FOREACH_NOT_IGNORED(block) {
2726         g_free(block->clear_bmap);
2727         block->clear_bmap = NULL;
2728         g_free(block->bmap);
2729         block->bmap = NULL;
2730     }
2731
2732     xbzrle_cleanup();
2733     compress_threads_save_cleanup();
2734     ram_state_cleanup(rsp);
2735     g_free(migration_ops);
2736     migration_ops = NULL;
2737 }
2738
2739 static void ram_state_reset(RAMState *rs)
2740 {
2741     int i;
2742
2743     for (i = 0; i < RAM_CHANNEL_MAX; i++) {
2744         rs->pss[i].last_sent_block = NULL;
2745     }
2746
2747     rs->last_seen_block = NULL;
2748     rs->last_page = 0;
2749     rs->last_version = ram_list.version;
2750     rs->xbzrle_enabled = false;
2751 }
2752
2753 #define MAX_WAIT 50 /* ms, half buffered_file limit */
2754
2755 /* **** functions for postcopy ***** */
2756
2757 void ram_postcopy_migrated_memory_release(MigrationState *ms)
2758 {
2759     struct RAMBlock *block;
2760
2761     RAMBLOCK_FOREACH_NOT_IGNORED(block) {
2762         unsigned long *bitmap = block->bmap;
2763         unsigned long range = block->used_length >> TARGET_PAGE_BITS;
2764         unsigned long run_start = find_next_zero_bit(bitmap, range, 0);
2765
2766         while (run_start < range) {
2767             unsigned long run_end = find_next_bit(bitmap, range, run_start + 1);
2768             ram_discard_range(block->idstr,
2769                               ((ram_addr_t)run_start) << TARGET_PAGE_BITS,
2770                               ((ram_addr_t)(run_end - run_start))
2771                                 << TARGET_PAGE_BITS);
2772             run_start = find_next_zero_bit(bitmap, range, run_end + 1);
2773         }
2774     }
2775 }
2776
2777 /**
2778  * postcopy_send_discard_bm_ram: discard a RAMBlock
2779  *
2780  * Callback from postcopy_each_ram_send_discard for each RAMBlock
2781  *
2782  * @ms: current migration state
2783  * @block: RAMBlock to discard
2784  */
2785 static void postcopy_send_discard_bm_ram(MigrationState *ms, RAMBlock *block)
2786 {
2787     unsigned long end = block->used_length >> TARGET_PAGE_BITS;
2788     unsigned long current;
2789     unsigned long *bitmap = block->bmap;
2790
2791     for (current = 0; current < end; ) {
2792         unsigned long one = find_next_bit(bitmap, end, current);
2793         unsigned long zero, discard_length;
2794
2795         if (one >= end) {
2796             break;
2797         }
2798
2799         zero = find_next_zero_bit(bitmap, end, one + 1);
2800
2801         if (zero >= end) {
2802             discard_length = end - one;
2803         } else {
2804             discard_length = zero - one;
2805         }
2806         postcopy_discard_send_range(ms, one, discard_length);
2807         current = one + discard_length;
2808     }
2809 }
2810
2811 static void postcopy_chunk_hostpages_pass(MigrationState *ms, RAMBlock *block);
2812
2813 /**
2814  * postcopy_each_ram_send_discard: discard all RAMBlocks
2815  *
2816  * Utility for the outgoing postcopy code.
2817  *   Calls postcopy_send_discard_bm_ram for each RAMBlock
2818  *   passing it bitmap indexes and name.
2819  * (qemu_ram_foreach_block ends up passing unscaled lengths
2820  *  which would mean postcopy code would have to deal with target page)
2821  *
2822  * @ms: current migration state
2823  */
2824 static void postcopy_each_ram_send_discard(MigrationState *ms)
2825 {
2826     struct RAMBlock *block;
2827
2828     RAMBLOCK_FOREACH_NOT_IGNORED(block) {
2829         postcopy_discard_send_init(ms, block->idstr);
2830
2831         /*
2832          * Deal with TPS != HPS and huge pages.  It discard any partially sent
2833          * host-page size chunks, mark any partially dirty host-page size
2834          * chunks as all dirty.  In this case the host-page is the host-page
2835          * for the particular RAMBlock, i.e. it might be a huge page.
2836          */
2837         postcopy_chunk_hostpages_pass(ms, block);
2838
2839         /*
2840          * Postcopy sends chunks of bitmap over the wire, but it
2841          * just needs indexes at this point, avoids it having
2842          * target page specific code.
2843          */
2844         postcopy_send_discard_bm_ram(ms, block);
2845         postcopy_discard_send_finish(ms);
2846     }
2847 }
2848
2849 /**
2850  * postcopy_chunk_hostpages_pass: canonicalize bitmap in hostpages
2851  *
2852  * Helper for postcopy_chunk_hostpages; it's called twice to
2853  * canonicalize the two bitmaps, that are similar, but one is
2854  * inverted.
2855  *
2856  * Postcopy requires that all target pages in a hostpage are dirty or
2857  * clean, not a mix.  This function canonicalizes the bitmaps.
2858  *
2859  * @ms: current migration state
2860  * @block: block that contains the page we want to canonicalize
2861  */
2862 static void postcopy_chunk_hostpages_pass(MigrationState *ms, RAMBlock *block)
2863 {
2864     RAMState *rs = ram_state;
2865     unsigned long *bitmap = block->bmap;
2866     unsigned int host_ratio = block->page_size / TARGET_PAGE_SIZE;
2867     unsigned long pages = block->used_length >> TARGET_PAGE_BITS;
2868     unsigned long run_start;
2869
2870     if (block->page_size == TARGET_PAGE_SIZE) {
2871         /* Easy case - TPS==HPS for a non-huge page RAMBlock */
2872         return;
2873     }
2874
2875     /* Find a dirty page */
2876     run_start = find_next_bit(bitmap, pages, 0);
2877
2878     while (run_start < pages) {
2879
2880         /*
2881          * If the start of this run of pages is in the middle of a host
2882          * page, then we need to fixup this host page.
2883          */
2884         if (QEMU_IS_ALIGNED(run_start, host_ratio)) {
2885             /* Find the end of this run */
2886             run_start = find_next_zero_bit(bitmap, pages, run_start + 1);
2887             /*
2888              * If the end isn't at the start of a host page, then the
2889              * run doesn't finish at the end of a host page
2890              * and we need to discard.
2891              */
2892         }
2893
2894         if (!QEMU_IS_ALIGNED(run_start, host_ratio)) {
2895             unsigned long page;
2896             unsigned long fixup_start_addr = QEMU_ALIGN_DOWN(run_start,
2897                                                              host_ratio);
2898             run_start = QEMU_ALIGN_UP(run_start, host_ratio);
2899
2900             /* Clean up the bitmap */
2901             for (page = fixup_start_addr;
2902                  page < fixup_start_addr + host_ratio; page++) {
2903                 /*
2904                  * Remark them as dirty, updating the count for any pages
2905                  * that weren't previously dirty.
2906                  */
2907                 rs->migration_dirty_pages += !test_and_set_bit(page, bitmap);
2908             }
2909         }
2910
2911         /* Find the next dirty page for the next iteration */
2912         run_start = find_next_bit(bitmap, pages, run_start);
2913     }
2914 }
2915
2916 /**
2917  * ram_postcopy_send_discard_bitmap: transmit the discard bitmap
2918  *
2919  * Transmit the set of pages to be discarded after precopy to the target
2920  * these are pages that:
2921  *     a) Have been previously transmitted but are now dirty again
2922  *     b) Pages that have never been transmitted, this ensures that
2923  *        any pages on the destination that have been mapped by background
2924  *        tasks get discarded (transparent huge pages is the specific concern)
2925  * Hopefully this is pretty sparse
2926  *
2927  * @ms: current migration state
2928  */
2929 void ram_postcopy_send_discard_bitmap(MigrationState *ms)
2930 {
2931     RAMState *rs = ram_state;
2932
2933     RCU_READ_LOCK_GUARD();
2934
2935     /* This should be our last sync, the src is now paused */
2936     migration_bitmap_sync(rs);
2937
2938     /* Easiest way to make sure we don't resume in the middle of a host-page */
2939     rs->pss[RAM_CHANNEL_PRECOPY].last_sent_block = NULL;
2940     rs->last_seen_block = NULL;
2941     rs->last_page = 0;
2942
2943     postcopy_each_ram_send_discard(ms);
2944
2945     trace_ram_postcopy_send_discard_bitmap();
2946 }
2947
2948 /**
2949  * ram_discard_range: discard dirtied pages at the beginning of postcopy
2950  *
2951  * Returns zero on success
2952  *
2953  * @rbname: name of the RAMBlock of the request. NULL means the
2954  *          same that last one.
2955  * @start: RAMBlock starting page
2956  * @length: RAMBlock size
2957  */
2958 int ram_discard_range(const char *rbname, uint64_t start, size_t length)
2959 {
2960     trace_ram_discard_range(rbname, start, length);
2961
2962     RCU_READ_LOCK_GUARD();
2963     RAMBlock *rb = qemu_ram_block_by_name(rbname);
2964
2965     if (!rb) {
2966         error_report("ram_discard_range: Failed to find block '%s'", rbname);
2967         return -1;
2968     }
2969
2970     /*
2971      * On source VM, we don't need to update the received bitmap since
2972      * we don't even have one.
2973      */
2974     if (rb->receivedmap) {
2975         bitmap_clear(rb->receivedmap, start >> qemu_target_page_bits(),
2976                      length >> qemu_target_page_bits());
2977     }
2978
2979     return ram_block_discard_range(rb, start, length);
2980 }
2981
2982 /*
2983  * For every allocation, we will try not to crash the VM if the
2984  * allocation failed.
2985  */
2986 static int xbzrle_init(void)
2987 {
2988     Error *local_err = NULL;
2989
2990     if (!migrate_xbzrle()) {
2991         return 0;
2992     }
2993
2994     XBZRLE_cache_lock();
2995
2996     XBZRLE.zero_target_page = g_try_malloc0(TARGET_PAGE_SIZE);
2997     if (!XBZRLE.zero_target_page) {
2998         error_report("%s: Error allocating zero page", __func__);
2999         goto err_out;
3000     }
3001
3002     XBZRLE.cache = cache_init(migrate_xbzrle_cache_size(),
3003                               TARGET_PAGE_SIZE, &local_err);
3004     if (!XBZRLE.cache) {
3005         error_report_err(local_err);
3006         goto free_zero_page;
3007     }
3008
3009     XBZRLE.encoded_buf = g_try_malloc0(TARGET_PAGE_SIZE);
3010     if (!XBZRLE.encoded_buf) {
3011         error_report("%s: Error allocating encoded_buf", __func__);
3012         goto free_cache;
3013     }
3014
3015     XBZRLE.current_buf = g_try_malloc(TARGET_PAGE_SIZE);
3016     if (!XBZRLE.current_buf) {
3017         error_report("%s: Error allocating current_buf", __func__);
3018         goto free_encoded_buf;
3019     }
3020
3021     /* We are all good */
3022     XBZRLE_cache_unlock();
3023     return 0;
3024
3025 free_encoded_buf:
3026     g_free(XBZRLE.encoded_buf);
3027     XBZRLE.encoded_buf = NULL;
3028 free_cache:
3029     cache_fini(XBZRLE.cache);
3030     XBZRLE.cache = NULL;
3031 free_zero_page:
3032     g_free(XBZRLE.zero_target_page);
3033     XBZRLE.zero_target_page = NULL;
3034 err_out:
3035     XBZRLE_cache_unlock();
3036     return -ENOMEM;
3037 }
3038
3039 static int ram_state_init(RAMState **rsp)
3040 {
3041     *rsp = g_try_new0(RAMState, 1);
3042
3043     if (!*rsp) {
3044         error_report("%s: Init ramstate fail", __func__);
3045         return -1;
3046     }
3047
3048     qemu_mutex_init(&(*rsp)->bitmap_mutex);
3049     qemu_mutex_init(&(*rsp)->src_page_req_mutex);
3050     QSIMPLEQ_INIT(&(*rsp)->src_page_requests);
3051     (*rsp)->ram_bytes_total = ram_bytes_total();
3052
3053     /*
3054      * Count the total number of pages used by ram blocks not including any
3055      * gaps due to alignment or unplugs.
3056      * This must match with the initial values of dirty bitmap.
3057      */
3058     (*rsp)->migration_dirty_pages = (*rsp)->ram_bytes_total >> TARGET_PAGE_BITS;
3059     ram_state_reset(*rsp);
3060
3061     return 0;
3062 }
3063
3064 static void ram_list_init_bitmaps(void)
3065 {
3066     MigrationState *ms = migrate_get_current();
3067     RAMBlock *block;
3068     unsigned long pages;
3069     uint8_t shift;
3070
3071     /* Skip setting bitmap if there is no RAM */
3072     if (ram_bytes_total()) {
3073         shift = ms->clear_bitmap_shift;
3074         if (shift > CLEAR_BITMAP_SHIFT_MAX) {
3075             error_report("clear_bitmap_shift (%u) too big, using "
3076                          "max value (%u)", shift, CLEAR_BITMAP_SHIFT_MAX);
3077             shift = CLEAR_BITMAP_SHIFT_MAX;
3078         } else if (shift < CLEAR_BITMAP_SHIFT_MIN) {
3079             error_report("clear_bitmap_shift (%u) too small, using "
3080                          "min value (%u)", shift, CLEAR_BITMAP_SHIFT_MIN);
3081             shift = CLEAR_BITMAP_SHIFT_MIN;
3082         }
3083
3084         RAMBLOCK_FOREACH_NOT_IGNORED(block) {
3085             pages = block->max_length >> TARGET_PAGE_BITS;
3086             /*
3087              * The initial dirty bitmap for migration must be set with all
3088              * ones to make sure we'll migrate every guest RAM page to
3089              * destination.
3090              * Here we set RAMBlock.bmap all to 1 because when rebegin a
3091              * new migration after a failed migration, ram_list.
3092              * dirty_memory[DIRTY_MEMORY_MIGRATION] don't include the whole
3093              * guest memory.
3094              */
3095             block->bmap = bitmap_new(pages);
3096             bitmap_set(block->bmap, 0, pages);
3097             block->clear_bmap_shift = shift;
3098             block->clear_bmap = bitmap_new(clear_bmap_size(pages, shift));
3099         }
3100     }
3101 }
3102
3103 static void migration_bitmap_clear_discarded_pages(RAMState *rs)
3104 {
3105     unsigned long pages;
3106     RAMBlock *rb;
3107
3108     RCU_READ_LOCK_GUARD();
3109
3110     RAMBLOCK_FOREACH_NOT_IGNORED(rb) {
3111             pages = ramblock_dirty_bitmap_clear_discarded_pages(rb);
3112             rs->migration_dirty_pages -= pages;
3113     }
3114 }
3115
3116 static void ram_init_bitmaps(RAMState *rs)
3117 {
3118     /* For memory_global_dirty_log_start below.  */
3119     qemu_mutex_lock_iothread();
3120     qemu_mutex_lock_ramlist();
3121
3122     WITH_RCU_READ_LOCK_GUARD() {
3123         ram_list_init_bitmaps();
3124         /* We don't use dirty log with background snapshots */
3125         if (!migrate_background_snapshot()) {
3126             memory_global_dirty_log_start(GLOBAL_DIRTY_MIGRATION);
3127             migration_bitmap_sync_precopy(rs);
3128         }
3129     }
3130     qemu_mutex_unlock_ramlist();
3131     qemu_mutex_unlock_iothread();
3132
3133     /*
3134      * After an eventual first bitmap sync, fixup the initial bitmap
3135      * containing all 1s to exclude any discarded pages from migration.
3136      */
3137     migration_bitmap_clear_discarded_pages(rs);
3138 }
3139
3140 static int ram_init_all(RAMState **rsp)
3141 {
3142     if (ram_state_init(rsp)) {
3143         return -1;
3144     }
3145
3146     if (xbzrle_init()) {
3147         ram_state_cleanup(rsp);
3148         return -1;
3149     }
3150
3151     ram_init_bitmaps(*rsp);
3152
3153     return 0;
3154 }
3155
3156 static void ram_state_resume_prepare(RAMState *rs, QEMUFile *out)
3157 {
3158     RAMBlock *block;
3159     uint64_t pages = 0;
3160
3161     /*
3162      * Postcopy is not using xbzrle/compression, so no need for that.
3163      * Also, since source are already halted, we don't need to care
3164      * about dirty page logging as well.
3165      */
3166
3167     RAMBLOCK_FOREACH_NOT_IGNORED(block) {
3168         pages += bitmap_count_one(block->bmap,
3169                                   block->used_length >> TARGET_PAGE_BITS);
3170     }
3171
3172     /* This may not be aligned with current bitmaps. Recalculate. */
3173     rs->migration_dirty_pages = pages;
3174
3175     ram_state_reset(rs);
3176
3177     /* Update RAMState cache of output QEMUFile */
3178     rs->pss[RAM_CHANNEL_PRECOPY].pss_channel = out;
3179
3180     trace_ram_state_resume_prepare(pages);
3181 }
3182
3183 /*
3184  * This function clears bits of the free pages reported by the caller from the
3185  * migration dirty bitmap. @addr is the host address corresponding to the
3186  * start of the continuous guest free pages, and @len is the total bytes of
3187  * those pages.
3188  */
3189 void qemu_guest_free_page_hint(void *addr, size_t len)
3190 {
3191     RAMBlock *block;
3192     ram_addr_t offset;
3193     size_t used_len, start, npages;
3194     MigrationState *s = migrate_get_current();
3195
3196     /* This function is currently expected to be used during live migration */
3197     if (!migration_is_setup_or_active(s->state)) {
3198         return;
3199     }
3200
3201     for (; len > 0; len -= used_len, addr += used_len) {
3202         block = qemu_ram_block_from_host(addr, false, &offset);
3203         if (unlikely(!block || offset >= block->used_length)) {
3204             /*
3205              * The implementation might not support RAMBlock resize during
3206              * live migration, but it could happen in theory with future
3207              * updates. So we add a check here to capture that case.
3208              */
3209             error_report_once("%s unexpected error", __func__);
3210             return;
3211         }
3212
3213         if (len <= block->used_length - offset) {
3214             used_len = len;
3215         } else {
3216             used_len = block->used_length - offset;
3217         }
3218
3219         start = offset >> TARGET_PAGE_BITS;
3220         npages = used_len >> TARGET_PAGE_BITS;
3221
3222         qemu_mutex_lock(&ram_state->bitmap_mutex);
3223         /*
3224          * The skipped free pages are equavalent to be sent from clear_bmap's
3225          * perspective, so clear the bits from the memory region bitmap which
3226          * are initially set. Otherwise those skipped pages will be sent in
3227          * the next round after syncing from the memory region bitmap.
3228          */
3229         migration_clear_memory_region_dirty_bitmap_range(block, start, npages);
3230         ram_state->migration_dirty_pages -=
3231                       bitmap_count_one_with_offset(block->bmap, start, npages);
3232         bitmap_clear(block->bmap, start, npages);
3233         qemu_mutex_unlock(&ram_state->bitmap_mutex);
3234     }
3235 }
3236
3237 /*
3238  * Each of ram_save_setup, ram_save_iterate and ram_save_complete has
3239  * long-running RCU critical section.  When rcu-reclaims in the code
3240  * start to become numerous it will be necessary to reduce the
3241  * granularity of these critical sections.
3242  */
3243
3244 /**
3245  * ram_save_setup: Setup RAM for migration
3246  *
3247  * Returns zero to indicate success and negative for error
3248  *
3249  * @f: QEMUFile where to send the data
3250  * @opaque: RAMState pointer
3251  */
3252 static int ram_save_setup(QEMUFile *f, void *opaque)
3253 {
3254     RAMState **rsp = opaque;
3255     RAMBlock *block;
3256     int ret;
3257
3258     if (compress_threads_save_setup()) {
3259         return -1;
3260     }
3261
3262     /* migration has already setup the bitmap, reuse it. */
3263     if (!migration_in_colo_state()) {
3264         if (ram_init_all(rsp) != 0) {
3265             compress_threads_save_cleanup();
3266             return -1;
3267         }
3268     }
3269     (*rsp)->pss[RAM_CHANNEL_PRECOPY].pss_channel = f;
3270
3271     WITH_RCU_READ_LOCK_GUARD() {
3272         qemu_put_be64(f, ram_bytes_total_with_ignored()
3273                          | RAM_SAVE_FLAG_MEM_SIZE);
3274
3275         RAMBLOCK_FOREACH_MIGRATABLE(block) {
3276             qemu_put_byte(f, strlen(block->idstr));
3277             qemu_put_buffer(f, (uint8_t *)block->idstr, strlen(block->idstr));
3278             qemu_put_be64(f, block->used_length);
3279             if (migrate_postcopy_ram() && block->page_size !=
3280                                           qemu_host_page_size) {
3281                 qemu_put_be64(f, block->page_size);
3282             }
3283             if (migrate_ignore_shared()) {
3284                 qemu_put_be64(f, block->mr->addr);
3285             }
3286         }
3287     }
3288
3289     ram_control_before_iterate(f, RAM_CONTROL_SETUP);
3290     ram_control_after_iterate(f, RAM_CONTROL_SETUP);
3291
3292     migration_ops = g_malloc0(sizeof(MigrationOps));
3293     migration_ops->ram_save_target_page = ram_save_target_page_legacy;
3294     ret = multifd_send_sync_main(f);
3295     if (ret < 0) {
3296         return ret;
3297     }
3298
3299     if (!migrate_multifd_flush_after_each_section()) {
3300         qemu_put_be64(f, RAM_SAVE_FLAG_MULTIFD_FLUSH);
3301     }
3302
3303     qemu_put_be64(f, RAM_SAVE_FLAG_EOS);
3304     qemu_fflush(f);
3305
3306     return 0;
3307 }
3308
3309 /**
3310  * ram_save_iterate: iterative stage for migration
3311  *
3312  * Returns zero to indicate success and negative for error
3313  *
3314  * @f: QEMUFile where to send the data
3315  * @opaque: RAMState pointer
3316  */
3317 static int ram_save_iterate(QEMUFile *f, void *opaque)
3318 {
3319     RAMState **temp = opaque;
3320     RAMState *rs = *temp;
3321     int ret = 0;
3322     int i;
3323     int64_t t0;
3324     int done = 0;
3325
3326     if (blk_mig_bulk_active()) {
3327         /* Avoid transferring ram during bulk phase of block migration as
3328          * the bulk phase will usually take a long time and transferring
3329          * ram updates during that time is pointless. */
3330         goto out;
3331     }
3332
3333     /*
3334      * We'll take this lock a little bit long, but it's okay for two reasons.
3335      * Firstly, the only possible other thread to take it is who calls
3336      * qemu_guest_free_page_hint(), which should be rare; secondly, see
3337      * MAX_WAIT (if curious, further see commit 4508bd9ed8053ce) below, which
3338      * guarantees that we'll at least released it in a regular basis.
3339      */
3340     qemu_mutex_lock(&rs->bitmap_mutex);
3341     WITH_RCU_READ_LOCK_GUARD() {
3342         if (ram_list.version != rs->last_version) {
3343             ram_state_reset(rs);
3344         }
3345
3346         /* Read version before ram_list.blocks */
3347         smp_rmb();
3348
3349         ram_control_before_iterate(f, RAM_CONTROL_ROUND);
3350
3351         t0 = qemu_clock_get_ns(QEMU_CLOCK_REALTIME);
3352         i = 0;
3353         while ((ret = qemu_file_rate_limit(f)) == 0 ||
3354                postcopy_has_request(rs)) {
3355             int pages;
3356
3357             if (qemu_file_get_error(f)) {
3358                 break;
3359             }
3360
3361             pages = ram_find_and_save_block(rs);
3362             /* no more pages to sent */
3363             if (pages == 0) {
3364                 done = 1;
3365                 break;
3366             }
3367
3368             if (pages < 0) {
3369                 qemu_file_set_error(f, pages);
3370                 break;
3371             }
3372
3373             rs->target_page_count += pages;
3374
3375             /*
3376              * During postcopy, it is necessary to make sure one whole host
3377              * page is sent in one chunk.
3378              */
3379             if (migrate_postcopy_ram()) {
3380                 flush_compressed_data(rs);
3381             }
3382
3383             /*
3384              * we want to check in the 1st loop, just in case it was the 1st
3385              * time and we had to sync the dirty bitmap.
3386              * qemu_clock_get_ns() is a bit expensive, so we only check each
3387              * some iterations
3388              */
3389             if ((i & 63) == 0) {
3390                 uint64_t t1 = (qemu_clock_get_ns(QEMU_CLOCK_REALTIME) - t0) /
3391                               1000000;
3392                 if (t1 > MAX_WAIT) {
3393                     trace_ram_save_iterate_big_wait(t1, i);
3394                     break;
3395                 }
3396             }
3397             i++;
3398         }
3399     }
3400     qemu_mutex_unlock(&rs->bitmap_mutex);
3401
3402     /*
3403      * Must occur before EOS (or any QEMUFile operation)
3404      * because of RDMA protocol.
3405      */
3406     ram_control_after_iterate(f, RAM_CONTROL_ROUND);
3407
3408 out:
3409     if (ret >= 0
3410         && migration_is_setup_or_active(migrate_get_current()->state)) {
3411         if (migrate_multifd_flush_after_each_section()) {
3412             ret = multifd_send_sync_main(rs->pss[RAM_CHANNEL_PRECOPY].pss_channel);
3413             if (ret < 0) {
3414                 return ret;
3415             }
3416         }
3417
3418         qemu_put_be64(f, RAM_SAVE_FLAG_EOS);
3419         qemu_fflush(f);
3420         ram_transferred_add(8);
3421
3422         ret = qemu_file_get_error(f);
3423     }
3424     if (ret < 0) {
3425         return ret;
3426     }
3427
3428     return done;
3429 }
3430
3431 /**
3432  * ram_save_complete: function called to send the remaining amount of ram
3433  *
3434  * Returns zero to indicate success or negative on error
3435  *
3436  * Called with iothread lock
3437  *
3438  * @f: QEMUFile where to send the data
3439  * @opaque: RAMState pointer
3440  */
3441 static int ram_save_complete(QEMUFile *f, void *opaque)
3442 {
3443     RAMState **temp = opaque;
3444     RAMState *rs = *temp;
3445     int ret = 0;
3446
3447     rs->last_stage = !migration_in_colo_state();
3448
3449     WITH_RCU_READ_LOCK_GUARD() {
3450         if (!migration_in_postcopy()) {
3451             migration_bitmap_sync_precopy(rs);
3452         }
3453
3454         ram_control_before_iterate(f, RAM_CONTROL_FINISH);
3455
3456         /* try transferring iterative blocks of memory */
3457
3458         /* flush all remaining blocks regardless of rate limiting */
3459         qemu_mutex_lock(&rs->bitmap_mutex);
3460         while (true) {
3461             int pages;
3462
3463             pages = ram_find_and_save_block(rs);
3464             /* no more blocks to sent */
3465             if (pages == 0) {
3466                 break;
3467             }
3468             if (pages < 0) {
3469                 ret = pages;
3470                 break;
3471             }
3472         }
3473         qemu_mutex_unlock(&rs->bitmap_mutex);
3474
3475         flush_compressed_data(rs);
3476         ram_control_after_iterate(f, RAM_CONTROL_FINISH);
3477     }
3478
3479     if (ret < 0) {
3480         return ret;
3481     }
3482
3483     ret = multifd_send_sync_main(rs->pss[RAM_CHANNEL_PRECOPY].pss_channel);
3484     if (ret < 0) {
3485         return ret;
3486     }
3487
3488     if (!migrate_multifd_flush_after_each_section()) {
3489         qemu_put_be64(f, RAM_SAVE_FLAG_MULTIFD_FLUSH);
3490     }
3491     qemu_put_be64(f, RAM_SAVE_FLAG_EOS);
3492     qemu_fflush(f);
3493
3494     return 0;
3495 }
3496
3497 static void ram_state_pending_estimate(void *opaque, uint64_t *must_precopy,
3498                                        uint64_t *can_postcopy)
3499 {
3500     RAMState **temp = opaque;
3501     RAMState *rs = *temp;
3502
3503     uint64_t remaining_size = rs->migration_dirty_pages * TARGET_PAGE_SIZE;
3504
3505     if (migrate_postcopy_ram()) {
3506         /* We can do postcopy, and all the data is postcopiable */
3507         *can_postcopy += remaining_size;
3508     } else {
3509         *must_precopy += remaining_size;
3510     }
3511 }
3512
3513 static void ram_state_pending_exact(void *opaque, uint64_t *must_precopy,
3514                                     uint64_t *can_postcopy)
3515 {
3516     MigrationState *s = migrate_get_current();
3517     RAMState **temp = opaque;
3518     RAMState *rs = *temp;
3519
3520     uint64_t remaining_size = rs->migration_dirty_pages * TARGET_PAGE_SIZE;
3521
3522     if (!migration_in_postcopy() && remaining_size < s->threshold_size) {
3523         qemu_mutex_lock_iothread();
3524         WITH_RCU_READ_LOCK_GUARD() {
3525             migration_bitmap_sync_precopy(rs);
3526         }
3527         qemu_mutex_unlock_iothread();
3528         remaining_size = rs->migration_dirty_pages * TARGET_PAGE_SIZE;
3529     }
3530
3531     if (migrate_postcopy_ram()) {
3532         /* We can do postcopy, and all the data is postcopiable */
3533         *can_postcopy += remaining_size;
3534     } else {
3535         *must_precopy += remaining_size;
3536     }
3537 }
3538
3539 static int load_xbzrle(QEMUFile *f, ram_addr_t addr, void *host)
3540 {
3541     unsigned int xh_len;
3542     int xh_flags;
3543     uint8_t *loaded_data;
3544
3545     /* extract RLE header */
3546     xh_flags = qemu_get_byte(f);
3547     xh_len = qemu_get_be16(f);
3548
3549     if (xh_flags != ENCODING_FLAG_XBZRLE) {
3550         error_report("Failed to load XBZRLE page - wrong compression!");
3551         return -1;
3552     }
3553
3554     if (xh_len > TARGET_PAGE_SIZE) {
3555         error_report("Failed to load XBZRLE page - len overflow!");
3556         return -1;
3557     }
3558     loaded_data = XBZRLE.decoded_buf;
3559     /* load data and decode */
3560     /* it can change loaded_data to point to an internal buffer */
3561     qemu_get_buffer_in_place(f, &loaded_data, xh_len);
3562
3563     /* decode RLE */
3564     if (xbzrle_decode_buffer(loaded_data, xh_len, host,
3565                              TARGET_PAGE_SIZE) == -1) {
3566         error_report("Failed to load XBZRLE page - decode error!");
3567         return -1;
3568     }
3569
3570     return 0;
3571 }
3572
3573 /**
3574  * ram_block_from_stream: read a RAMBlock id from the migration stream
3575  *
3576  * Must be called from within a rcu critical section.
3577  *
3578  * Returns a pointer from within the RCU-protected ram_list.
3579  *
3580  * @mis: the migration incoming state pointer
3581  * @f: QEMUFile where to read the data from
3582  * @flags: Page flags (mostly to see if it's a continuation of previous block)
3583  * @channel: the channel we're using
3584  */
3585 static inline RAMBlock *ram_block_from_stream(MigrationIncomingState *mis,
3586                                               QEMUFile *f, int flags,
3587                                               int channel)
3588 {
3589     RAMBlock *block = mis->last_recv_block[channel];
3590     char id[256];
3591     uint8_t len;
3592
3593     if (flags & RAM_SAVE_FLAG_CONTINUE) {
3594         if (!block) {
3595             error_report("Ack, bad migration stream!");
3596             return NULL;
3597         }
3598         return block;
3599     }
3600
3601     len = qemu_get_byte(f);
3602     qemu_get_buffer(f, (uint8_t *)id, len);
3603     id[len] = 0;
3604
3605     block = qemu_ram_block_by_name(id);
3606     if (!block) {
3607         error_report("Can't find block %s", id);
3608         return NULL;
3609     }
3610
3611     if (ramblock_is_ignored(block)) {
3612         error_report("block %s should not be migrated !", id);
3613         return NULL;
3614     }
3615
3616     mis->last_recv_block[channel] = block;
3617
3618     return block;
3619 }
3620
3621 static inline void *host_from_ram_block_offset(RAMBlock *block,
3622                                                ram_addr_t offset)
3623 {
3624     if (!offset_in_ramblock(block, offset)) {
3625         return NULL;
3626     }
3627
3628     return block->host + offset;
3629 }
3630
3631 static void *host_page_from_ram_block_offset(RAMBlock *block,
3632                                              ram_addr_t offset)
3633 {
3634     /* Note: Explicitly no check against offset_in_ramblock(). */
3635     return (void *)QEMU_ALIGN_DOWN((uintptr_t)(block->host + offset),
3636                                    block->page_size);
3637 }
3638
3639 static ram_addr_t host_page_offset_from_ram_block_offset(RAMBlock *block,
3640                                                          ram_addr_t offset)
3641 {
3642     return ((uintptr_t)block->host + offset) & (block->page_size - 1);
3643 }
3644
3645 static inline void *colo_cache_from_block_offset(RAMBlock *block,
3646                              ram_addr_t offset, bool record_bitmap)
3647 {
3648     if (!offset_in_ramblock(block, offset)) {
3649         return NULL;
3650     }
3651     if (!block->colo_cache) {
3652         error_report("%s: colo_cache is NULL in block :%s",
3653                      __func__, block->idstr);
3654         return NULL;
3655     }
3656
3657     /*
3658     * During colo checkpoint, we need bitmap of these migrated pages.
3659     * It help us to decide which pages in ram cache should be flushed
3660     * into VM's RAM later.
3661     */
3662     if (record_bitmap &&
3663         !test_and_set_bit(offset >> TARGET_PAGE_BITS, block->bmap)) {
3664         ram_state->migration_dirty_pages++;
3665     }
3666     return block->colo_cache + offset;
3667 }
3668
3669 /**
3670  * ram_handle_compressed: handle the zero page case
3671  *
3672  * If a page (or a whole RDMA chunk) has been
3673  * determined to be zero, then zap it.
3674  *
3675  * @host: host address for the zero page
3676  * @ch: what the page is filled from.  We only support zero
3677  * @size: size of the zero page
3678  */
3679 void ram_handle_compressed(void *host, uint8_t ch, uint64_t size)
3680 {
3681     if (ch != 0 || !buffer_is_zero(host, size)) {
3682         memset(host, ch, size);
3683     }
3684 }
3685
3686 /* return the size after decompression, or negative value on error */
3687 static int
3688 qemu_uncompress_data(z_stream *stream, uint8_t *dest, size_t dest_len,
3689                      const uint8_t *source, size_t source_len)
3690 {
3691     int err;
3692
3693     err = inflateReset(stream);
3694     if (err != Z_OK) {
3695         return -1;
3696     }
3697
3698     stream->avail_in = source_len;
3699     stream->next_in = (uint8_t *)source;
3700     stream->avail_out = dest_len;
3701     stream->next_out = dest;
3702
3703     err = inflate(stream, Z_NO_FLUSH);
3704     if (err != Z_STREAM_END) {
3705         return -1;
3706     }
3707
3708     return stream->total_out;
3709 }
3710
3711 static void *do_data_decompress(void *opaque)
3712 {
3713     DecompressParam *param = opaque;
3714     unsigned long pagesize;
3715     uint8_t *des;
3716     int len, ret;
3717
3718     qemu_mutex_lock(&param->mutex);
3719     while (!param->quit) {
3720         if (param->des) {
3721             des = param->des;
3722             len = param->len;
3723             param->des = 0;
3724             qemu_mutex_unlock(&param->mutex);
3725
3726             pagesize = TARGET_PAGE_SIZE;
3727
3728             ret = qemu_uncompress_data(&param->stream, des, pagesize,
3729                                        param->compbuf, len);
3730             if (ret < 0 && migrate_get_current()->decompress_error_check) {
3731                 error_report("decompress data failed");
3732                 qemu_file_set_error(decomp_file, ret);
3733             }
3734
3735             qemu_mutex_lock(&decomp_done_lock);
3736             param->done = true;
3737             qemu_cond_signal(&decomp_done_cond);
3738             qemu_mutex_unlock(&decomp_done_lock);
3739
3740             qemu_mutex_lock(&param->mutex);
3741         } else {
3742             qemu_cond_wait(&param->cond, &param->mutex);
3743         }
3744     }
3745     qemu_mutex_unlock(&param->mutex);
3746
3747     return NULL;
3748 }
3749
3750 static int wait_for_decompress_done(void)
3751 {
3752     int idx, thread_count;
3753
3754     if (!migrate_compress()) {
3755         return 0;
3756     }
3757
3758     thread_count = migrate_decompress_threads();
3759     qemu_mutex_lock(&decomp_done_lock);
3760     for (idx = 0; idx < thread_count; idx++) {
3761         while (!decomp_param[idx].done) {
3762             qemu_cond_wait(&decomp_done_cond, &decomp_done_lock);
3763         }
3764     }
3765     qemu_mutex_unlock(&decomp_done_lock);
3766     return qemu_file_get_error(decomp_file);
3767 }
3768
3769 static void compress_threads_load_cleanup(void)
3770 {
3771     int i, thread_count;
3772
3773     if (!migrate_compress()) {
3774         return;
3775     }
3776     thread_count = migrate_decompress_threads();
3777     for (i = 0; i < thread_count; i++) {
3778         /*
3779          * we use it as a indicator which shows if the thread is
3780          * properly init'd or not
3781          */
3782         if (!decomp_param[i].compbuf) {
3783             break;
3784         }
3785
3786         qemu_mutex_lock(&decomp_param[i].mutex);
3787         decomp_param[i].quit = true;
3788         qemu_cond_signal(&decomp_param[i].cond);
3789         qemu_mutex_unlock(&decomp_param[i].mutex);
3790     }
3791     for (i = 0; i < thread_count; i++) {
3792         if (!decomp_param[i].compbuf) {
3793             break;
3794         }
3795
3796         qemu_thread_join(decompress_threads + i);
3797         qemu_mutex_destroy(&decomp_param[i].mutex);
3798         qemu_cond_destroy(&decomp_param[i].cond);
3799         inflateEnd(&decomp_param[i].stream);
3800         g_free(decomp_param[i].compbuf);
3801         decomp_param[i].compbuf = NULL;
3802     }
3803     g_free(decompress_threads);
3804     g_free(decomp_param);
3805     decompress_threads = NULL;
3806     decomp_param = NULL;
3807     decomp_file = NULL;
3808 }
3809
3810 static int compress_threads_load_setup(QEMUFile *f)
3811 {
3812     int i, thread_count;
3813
3814     if (!migrate_compress()) {
3815         return 0;
3816     }
3817
3818     thread_count = migrate_decompress_threads();
3819     decompress_threads = g_new0(QemuThread, thread_count);
3820     decomp_param = g_new0(DecompressParam, thread_count);
3821     qemu_mutex_init(&decomp_done_lock);
3822     qemu_cond_init(&decomp_done_cond);
3823     decomp_file = f;
3824     for (i = 0; i < thread_count; i++) {
3825         if (inflateInit(&decomp_param[i].stream) != Z_OK) {
3826             goto exit;
3827         }
3828
3829         decomp_param[i].compbuf = g_malloc0(compressBound(TARGET_PAGE_SIZE));
3830         qemu_mutex_init(&decomp_param[i].mutex);
3831         qemu_cond_init(&decomp_param[i].cond);
3832         decomp_param[i].done = true;
3833         decomp_param[i].quit = false;
3834         qemu_thread_create(decompress_threads + i, "decompress",
3835                            do_data_decompress, decomp_param + i,
3836                            QEMU_THREAD_JOINABLE);
3837     }
3838     return 0;
3839 exit:
3840     compress_threads_load_cleanup();
3841     return -1;
3842 }
3843
3844 static void decompress_data_with_multi_threads(QEMUFile *f,
3845                                                void *host, int len)
3846 {
3847     int idx, thread_count;
3848
3849     thread_count = migrate_decompress_threads();
3850     QEMU_LOCK_GUARD(&decomp_done_lock);
3851     while (true) {
3852         for (idx = 0; idx < thread_count; idx++) {
3853             if (decomp_param[idx].done) {
3854                 decomp_param[idx].done = false;
3855                 qemu_mutex_lock(&decomp_param[idx].mutex);
3856                 qemu_get_buffer(f, decomp_param[idx].compbuf, len);
3857                 decomp_param[idx].des = host;
3858                 decomp_param[idx].len = len;
3859                 qemu_cond_signal(&decomp_param[idx].cond);
3860                 qemu_mutex_unlock(&decomp_param[idx].mutex);
3861                 break;
3862             }
3863         }
3864         if (idx < thread_count) {
3865             break;
3866         } else {
3867             qemu_cond_wait(&decomp_done_cond, &decomp_done_lock);
3868         }
3869     }
3870 }
3871
3872 static void colo_init_ram_state(void)
3873 {
3874     ram_state_init(&ram_state);
3875 }
3876
3877 /*
3878  * colo cache: this is for secondary VM, we cache the whole
3879  * memory of the secondary VM, it is need to hold the global lock
3880  * to call this helper.
3881  */
3882 int colo_init_ram_cache(void)
3883 {
3884     RAMBlock *block;
3885
3886     WITH_RCU_READ_LOCK_GUARD() {
3887         RAMBLOCK_FOREACH_NOT_IGNORED(block) {
3888             block->colo_cache = qemu_anon_ram_alloc(block->used_length,
3889                                                     NULL, false, false);
3890             if (!block->colo_cache) {
3891                 error_report("%s: Can't alloc memory for COLO cache of block %s,"
3892                              "size 0x" RAM_ADDR_FMT, __func__, block->idstr,
3893                              block->used_length);
3894                 RAMBLOCK_FOREACH_NOT_IGNORED(block) {
3895                     if (block->colo_cache) {
3896                         qemu_anon_ram_free(block->colo_cache, block->used_length);
3897                         block->colo_cache = NULL;
3898                     }
3899                 }
3900                 return -errno;
3901             }
3902             if (!machine_dump_guest_core(current_machine)) {
3903                 qemu_madvise(block->colo_cache, block->used_length,
3904                              QEMU_MADV_DONTDUMP);
3905             }
3906         }
3907     }
3908
3909     /*
3910     * Record the dirty pages that sent by PVM, we use this dirty bitmap together
3911     * with to decide which page in cache should be flushed into SVM's RAM. Here
3912     * we use the same name 'ram_bitmap' as for migration.
3913     */
3914     if (ram_bytes_total()) {
3915         RAMBlock *block;
3916
3917         RAMBLOCK_FOREACH_NOT_IGNORED(block) {
3918             unsigned long pages = block->max_length >> TARGET_PAGE_BITS;
3919             block->bmap = bitmap_new(pages);
3920         }
3921     }
3922
3923     colo_init_ram_state();
3924     return 0;
3925 }
3926
3927 /* TODO: duplicated with ram_init_bitmaps */
3928 void colo_incoming_start_dirty_log(void)
3929 {
3930     RAMBlock *block = NULL;
3931     /* For memory_global_dirty_log_start below. */
3932     qemu_mutex_lock_iothread();
3933     qemu_mutex_lock_ramlist();
3934
3935     memory_global_dirty_log_sync();
3936     WITH_RCU_READ_LOCK_GUARD() {
3937         RAMBLOCK_FOREACH_NOT_IGNORED(block) {
3938             ramblock_sync_dirty_bitmap(ram_state, block);
3939             /* Discard this dirty bitmap record */
3940             bitmap_zero(block->bmap, block->max_length >> TARGET_PAGE_BITS);
3941         }
3942         memory_global_dirty_log_start(GLOBAL_DIRTY_MIGRATION);
3943     }
3944     ram_state->migration_dirty_pages = 0;
3945     qemu_mutex_unlock_ramlist();
3946     qemu_mutex_unlock_iothread();
3947 }
3948
3949 /* It is need to hold the global lock to call this helper */
3950 void colo_release_ram_cache(void)
3951 {
3952     RAMBlock *block;
3953
3954     memory_global_dirty_log_stop(GLOBAL_DIRTY_MIGRATION);
3955     RAMBLOCK_FOREACH_NOT_IGNORED(block) {
3956         g_free(block->bmap);
3957         block->bmap = NULL;
3958     }
3959
3960     WITH_RCU_READ_LOCK_GUARD() {
3961         RAMBLOCK_FOREACH_NOT_IGNORED(block) {
3962             if (block->colo_cache) {
3963                 qemu_anon_ram_free(block->colo_cache, block->used_length);
3964                 block->colo_cache = NULL;
3965             }
3966         }
3967     }
3968     ram_state_cleanup(&ram_state);
3969 }
3970
3971 /**
3972  * ram_load_setup: Setup RAM for migration incoming side
3973  *
3974  * Returns zero to indicate success and negative for error
3975  *
3976  * @f: QEMUFile where to receive the data
3977  * @opaque: RAMState pointer
3978  */
3979 static int ram_load_setup(QEMUFile *f, void *opaque)
3980 {
3981     if (compress_threads_load_setup(f)) {
3982         return -1;
3983     }
3984
3985     xbzrle_load_setup();
3986     ramblock_recv_map_init();
3987
3988     return 0;
3989 }
3990
3991 static int ram_load_cleanup(void *opaque)
3992 {
3993     RAMBlock *rb;
3994
3995     RAMBLOCK_FOREACH_NOT_IGNORED(rb) {
3996         qemu_ram_block_writeback(rb);
3997     }
3998
3999     xbzrle_load_cleanup();
4000     compress_threads_load_cleanup();
4001
4002     RAMBLOCK_FOREACH_NOT_IGNORED(rb) {
4003         g_free(rb->receivedmap);
4004         rb->receivedmap = NULL;
4005     }
4006
4007     return 0;
4008 }
4009
4010 /**
4011  * ram_postcopy_incoming_init: allocate postcopy data structures
4012  *
4013  * Returns 0 for success and negative if there was one error
4014  *
4015  * @mis: current migration incoming state
4016  *
4017  * Allocate data structures etc needed by incoming migration with
4018  * postcopy-ram. postcopy-ram's similarly names
4019  * postcopy_ram_incoming_init does the work.
4020  */
4021 int ram_postcopy_incoming_init(MigrationIncomingState *mis)
4022 {
4023     return postcopy_ram_incoming_init(mis);
4024 }
4025
4026 /**
4027  * ram_load_postcopy: load a page in postcopy case
4028  *
4029  * Returns 0 for success or -errno in case of error
4030  *
4031  * Called in postcopy mode by ram_load().
4032  * rcu_read_lock is taken prior to this being called.
4033  *
4034  * @f: QEMUFile where to send the data
4035  * @channel: the channel to use for loading
4036  */
4037 int ram_load_postcopy(QEMUFile *f, int channel)
4038 {
4039     int flags = 0, ret = 0;
4040     bool place_needed = false;
4041     bool matches_target_page_size = false;
4042     MigrationIncomingState *mis = migration_incoming_get_current();
4043     PostcopyTmpPage *tmp_page = &mis->postcopy_tmp_pages[channel];
4044
4045     while (!ret && !(flags & RAM_SAVE_FLAG_EOS)) {
4046         ram_addr_t addr;
4047         void *page_buffer = NULL;
4048         void *place_source = NULL;
4049         RAMBlock *block = NULL;
4050         uint8_t ch;
4051         int len;
4052
4053         addr = qemu_get_be64(f);
4054
4055         /*
4056          * If qemu file error, we should stop here, and then "addr"
4057          * may be invalid
4058          */
4059         ret = qemu_file_get_error(f);
4060         if (ret) {
4061             break;
4062         }
4063
4064         flags = addr & ~TARGET_PAGE_MASK;
4065         addr &= TARGET_PAGE_MASK;
4066
4067         trace_ram_load_postcopy_loop(channel, (uint64_t)addr, flags);
4068         if (flags & (RAM_SAVE_FLAG_ZERO | RAM_SAVE_FLAG_PAGE |
4069                      RAM_SAVE_FLAG_COMPRESS_PAGE)) {
4070             block = ram_block_from_stream(mis, f, flags, channel);
4071             if (!block) {
4072                 ret = -EINVAL;
4073                 break;
4074             }
4075
4076             /*
4077              * Relying on used_length is racy and can result in false positives.
4078              * We might place pages beyond used_length in case RAM was shrunk
4079              * while in postcopy, which is fine - trying to place via
4080              * UFFDIO_COPY/UFFDIO_ZEROPAGE will never segfault.
4081              */
4082             if (!block->host || addr >= block->postcopy_length) {
4083                 error_report("Illegal RAM offset " RAM_ADDR_FMT, addr);
4084                 ret = -EINVAL;
4085                 break;
4086             }
4087             tmp_page->target_pages++;
4088             matches_target_page_size = block->page_size == TARGET_PAGE_SIZE;
4089             /*
4090              * Postcopy requires that we place whole host pages atomically;
4091              * these may be huge pages for RAMBlocks that are backed by
4092              * hugetlbfs.
4093              * To make it atomic, the data is read into a temporary page
4094              * that's moved into place later.
4095              * The migration protocol uses,  possibly smaller, target-pages
4096              * however the source ensures it always sends all the components
4097              * of a host page in one chunk.
4098              */
4099             page_buffer = tmp_page->tmp_huge_page +
4100                           host_page_offset_from_ram_block_offset(block, addr);
4101             /* If all TP are zero then we can optimise the place */
4102             if (tmp_page->target_pages == 1) {
4103                 tmp_page->host_addr =
4104                     host_page_from_ram_block_offset(block, addr);
4105             } else if (tmp_page->host_addr !=
4106                        host_page_from_ram_block_offset(block, addr)) {
4107                 /* not the 1st TP within the HP */
4108                 error_report("Non-same host page detected on channel %d: "
4109                              "Target host page %p, received host page %p "
4110                              "(rb %s offset 0x"RAM_ADDR_FMT" target_pages %d)",
4111                              channel, tmp_page->host_addr,
4112                              host_page_from_ram_block_offset(block, addr),
4113                              block->idstr, addr, tmp_page->target_pages);
4114                 ret = -EINVAL;
4115                 break;
4116             }
4117
4118             /*
4119              * If it's the last part of a host page then we place the host
4120              * page
4121              */
4122             if (tmp_page->target_pages ==
4123                 (block->page_size / TARGET_PAGE_SIZE)) {
4124                 place_needed = true;
4125             }
4126             place_source = tmp_page->tmp_huge_page;
4127         }
4128
4129         switch (flags & ~RAM_SAVE_FLAG_CONTINUE) {
4130         case RAM_SAVE_FLAG_ZERO:
4131             ch = qemu_get_byte(f);
4132             /*
4133              * Can skip to set page_buffer when
4134              * this is a zero page and (block->page_size == TARGET_PAGE_SIZE).
4135              */
4136             if (ch || !matches_target_page_size) {
4137                 memset(page_buffer, ch, TARGET_PAGE_SIZE);
4138             }
4139             if (ch) {
4140                 tmp_page->all_zero = false;
4141             }
4142             break;
4143
4144         case RAM_SAVE_FLAG_PAGE:
4145             tmp_page->all_zero = false;
4146             if (!matches_target_page_size) {
4147                 /* For huge pages, we always use temporary buffer */
4148                 qemu_get_buffer(f, page_buffer, TARGET_PAGE_SIZE);
4149             } else {
4150                 /*
4151                  * For small pages that matches target page size, we
4152                  * avoid the qemu_file copy.  Instead we directly use
4153                  * the buffer of QEMUFile to place the page.  Note: we
4154                  * cannot do any QEMUFile operation before using that
4155                  * buffer to make sure the buffer is valid when
4156                  * placing the page.
4157                  */
4158                 qemu_get_buffer_in_place(f, (uint8_t **)&place_source,
4159                                          TARGET_PAGE_SIZE);
4160             }
4161             break;
4162         case RAM_SAVE_FLAG_COMPRESS_PAGE:
4163             tmp_page->all_zero = false;
4164             len = qemu_get_be32(f);
4165             if (len < 0 || len > compressBound(TARGET_PAGE_SIZE)) {
4166                 error_report("Invalid compressed data length: %d", len);
4167                 ret = -EINVAL;
4168                 break;
4169             }
4170             decompress_data_with_multi_threads(f, page_buffer, len);
4171             break;
4172         case RAM_SAVE_FLAG_MULTIFD_FLUSH:
4173             multifd_recv_sync_main();
4174             break;
4175         case RAM_SAVE_FLAG_EOS:
4176             /* normal exit */
4177             if (migrate_multifd_flush_after_each_section()) {
4178                 multifd_recv_sync_main();
4179             }
4180             break;
4181         default:
4182             error_report("Unknown combination of migration flags: 0x%x"
4183                          " (postcopy mode)", flags);
4184             ret = -EINVAL;
4185             break;
4186         }
4187
4188         /* Got the whole host page, wait for decompress before placing. */
4189         if (place_needed) {
4190             ret |= wait_for_decompress_done();
4191         }
4192
4193         /* Detect for any possible file errors */
4194         if (!ret && qemu_file_get_error(f)) {
4195             ret = qemu_file_get_error(f);
4196         }
4197
4198         if (!ret && place_needed) {
4199             if (tmp_page->all_zero) {
4200                 ret = postcopy_place_page_zero(mis, tmp_page->host_addr, block);
4201             } else {
4202                 ret = postcopy_place_page(mis, tmp_page->host_addr,
4203                                           place_source, block);
4204             }
4205             place_needed = false;
4206             postcopy_temp_page_reset(tmp_page);
4207         }
4208     }
4209
4210     return ret;
4211 }
4212
4213 static bool postcopy_is_running(void)
4214 {
4215     PostcopyState ps = postcopy_state_get();
4216     return ps >= POSTCOPY_INCOMING_LISTENING && ps < POSTCOPY_INCOMING_END;
4217 }
4218
4219 /*
4220  * Flush content of RAM cache into SVM's memory.
4221  * Only flush the pages that be dirtied by PVM or SVM or both.
4222  */
4223 void colo_flush_ram_cache(void)
4224 {
4225     RAMBlock *block = NULL;
4226     void *dst_host;
4227     void *src_host;
4228     unsigned long offset = 0;
4229
4230     memory_global_dirty_log_sync();
4231     WITH_RCU_READ_LOCK_GUARD() {
4232         RAMBLOCK_FOREACH_NOT_IGNORED(block) {
4233             ramblock_sync_dirty_bitmap(ram_state, block);
4234         }
4235     }
4236
4237     trace_colo_flush_ram_cache_begin(ram_state->migration_dirty_pages);
4238     WITH_RCU_READ_LOCK_GUARD() {
4239         block = QLIST_FIRST_RCU(&ram_list.blocks);
4240
4241         while (block) {
4242             unsigned long num = 0;
4243
4244             offset = colo_bitmap_find_dirty(ram_state, block, offset, &num);
4245             if (!offset_in_ramblock(block,
4246                                     ((ram_addr_t)offset) << TARGET_PAGE_BITS)) {
4247                 offset = 0;
4248                 num = 0;
4249                 block = QLIST_NEXT_RCU(block, next);
4250             } else {
4251                 unsigned long i = 0;
4252
4253                 for (i = 0; i < num; i++) {
4254                     migration_bitmap_clear_dirty(ram_state, block, offset + i);
4255                 }
4256                 dst_host = block->host
4257                          + (((ram_addr_t)offset) << TARGET_PAGE_BITS);
4258                 src_host = block->colo_cache
4259                          + (((ram_addr_t)offset) << TARGET_PAGE_BITS);
4260                 memcpy(dst_host, src_host, TARGET_PAGE_SIZE * num);
4261                 offset += num;
4262             }
4263         }
4264     }
4265     trace_colo_flush_ram_cache_end();
4266 }
4267
4268 /**
4269  * ram_load_precopy: load pages in precopy case
4270  *
4271  * Returns 0 for success or -errno in case of error
4272  *
4273  * Called in precopy mode by ram_load().
4274  * rcu_read_lock is taken prior to this being called.
4275  *
4276  * @f: QEMUFile where to send the data
4277  */
4278 static int ram_load_precopy(QEMUFile *f)
4279 {
4280     MigrationIncomingState *mis = migration_incoming_get_current();
4281     int flags = 0, ret = 0, invalid_flags = 0, len = 0, i = 0;
4282     /* ADVISE is earlier, it shows the source has the postcopy capability on */
4283     bool postcopy_advised = migration_incoming_postcopy_advised();
4284     if (!migrate_compress()) {
4285         invalid_flags |= RAM_SAVE_FLAG_COMPRESS_PAGE;
4286     }
4287
4288     while (!ret && !(flags & RAM_SAVE_FLAG_EOS)) {
4289         ram_addr_t addr, total_ram_bytes;
4290         void *host = NULL, *host_bak = NULL;
4291         uint8_t ch;
4292
4293         /*
4294          * Yield periodically to let main loop run, but an iteration of
4295          * the main loop is expensive, so do it each some iterations
4296          */
4297         if ((i & 32767) == 0 && qemu_in_coroutine()) {
4298             aio_co_schedule(qemu_get_current_aio_context(),
4299                             qemu_coroutine_self());
4300             qemu_coroutine_yield();
4301         }
4302         i++;
4303
4304         addr = qemu_get_be64(f);
4305         flags = addr & ~TARGET_PAGE_MASK;
4306         addr &= TARGET_PAGE_MASK;
4307
4308         if (flags & invalid_flags) {
4309             if (flags & invalid_flags & RAM_SAVE_FLAG_COMPRESS_PAGE) {
4310                 error_report("Received an unexpected compressed page");
4311             }
4312
4313             ret = -EINVAL;
4314             break;
4315         }
4316
4317         if (flags & (RAM_SAVE_FLAG_ZERO | RAM_SAVE_FLAG_PAGE |
4318                      RAM_SAVE_FLAG_COMPRESS_PAGE | RAM_SAVE_FLAG_XBZRLE)) {
4319             RAMBlock *block = ram_block_from_stream(mis, f, flags,
4320                                                     RAM_CHANNEL_PRECOPY);
4321
4322             host = host_from_ram_block_offset(block, addr);
4323             /*
4324              * After going into COLO stage, we should not load the page
4325              * into SVM's memory directly, we put them into colo_cache firstly.
4326              * NOTE: We need to keep a copy of SVM's ram in colo_cache.
4327              * Previously, we copied all these memory in preparing stage of COLO
4328              * while we need to stop VM, which is a time-consuming process.
4329              * Here we optimize it by a trick, back-up every page while in
4330              * migration process while COLO is enabled, though it affects the
4331              * speed of the migration, but it obviously reduce the downtime of
4332              * back-up all SVM'S memory in COLO preparing stage.
4333              */
4334             if (migration_incoming_colo_enabled()) {
4335                 if (migration_incoming_in_colo_state()) {
4336                     /* In COLO stage, put all pages into cache temporarily */
4337                     host = colo_cache_from_block_offset(block, addr, true);
4338                 } else {
4339                    /*
4340                     * In migration stage but before COLO stage,
4341                     * Put all pages into both cache and SVM's memory.
4342                     */
4343                     host_bak = colo_cache_from_block_offset(block, addr, false);
4344                 }
4345             }
4346             if (!host) {
4347                 error_report("Illegal RAM offset " RAM_ADDR_FMT, addr);
4348                 ret = -EINVAL;
4349                 break;
4350             }
4351             if (!migration_incoming_in_colo_state()) {
4352                 ramblock_recv_bitmap_set(block, host);
4353             }
4354
4355             trace_ram_load_loop(block->idstr, (uint64_t)addr, flags, host);
4356         }
4357
4358         switch (flags & ~RAM_SAVE_FLAG_CONTINUE) {
4359         case RAM_SAVE_FLAG_MEM_SIZE:
4360             /* Synchronize RAM block list */
4361             total_ram_bytes = addr;
4362             while (!ret && total_ram_bytes) {
4363                 RAMBlock *block;
4364                 char id[256];
4365                 ram_addr_t length;
4366
4367                 len = qemu_get_byte(f);
4368                 qemu_get_buffer(f, (uint8_t *)id, len);
4369                 id[len] = 0;
4370                 length = qemu_get_be64(f);
4371
4372                 block = qemu_ram_block_by_name(id);
4373                 if (block && !qemu_ram_is_migratable(block)) {
4374                     error_report("block %s should not be migrated !", id);
4375                     ret = -EINVAL;
4376                 } else if (block) {
4377                     if (length != block->used_length) {
4378                         Error *local_err = NULL;
4379
4380                         ret = qemu_ram_resize(block, length,
4381                                               &local_err);
4382                         if (local_err) {
4383                             error_report_err(local_err);
4384                         }
4385                     }
4386                     /* For postcopy we need to check hugepage sizes match */
4387                     if (postcopy_advised && migrate_postcopy_ram() &&
4388                         block->page_size != qemu_host_page_size) {
4389                         uint64_t remote_page_size = qemu_get_be64(f);
4390                         if (remote_page_size != block->page_size) {
4391                             error_report("Mismatched RAM page size %s "
4392                                          "(local) %zd != %" PRId64,
4393                                          id, block->page_size,
4394                                          remote_page_size);
4395                             ret = -EINVAL;
4396                         }
4397                     }
4398                     if (migrate_ignore_shared()) {
4399                         hwaddr addr = qemu_get_be64(f);
4400                         if (ramblock_is_ignored(block) &&
4401                             block->mr->addr != addr) {
4402                             error_report("Mismatched GPAs for block %s "
4403                                          "%" PRId64 "!= %" PRId64,
4404                                          id, (uint64_t)addr,
4405                                          (uint64_t)block->mr->addr);
4406                             ret = -EINVAL;
4407                         }
4408                     }
4409                     ram_control_load_hook(f, RAM_CONTROL_BLOCK_REG,
4410                                           block->idstr);
4411                 } else {
4412                     error_report("Unknown ramblock \"%s\", cannot "
4413                                  "accept migration", id);
4414                     ret = -EINVAL;
4415                 }
4416
4417                 total_ram_bytes -= length;
4418             }
4419             break;
4420
4421         case RAM_SAVE_FLAG_ZERO:
4422             ch = qemu_get_byte(f);
4423             ram_handle_compressed(host, ch, TARGET_PAGE_SIZE);
4424             break;
4425
4426         case RAM_SAVE_FLAG_PAGE:
4427             qemu_get_buffer(f, host, TARGET_PAGE_SIZE);
4428             break;
4429
4430         case RAM_SAVE_FLAG_COMPRESS_PAGE:
4431             len = qemu_get_be32(f);
4432             if (len < 0 || len > compressBound(TARGET_PAGE_SIZE)) {
4433                 error_report("Invalid compressed data length: %d", len);
4434                 ret = -EINVAL;
4435                 break;
4436             }
4437             decompress_data_with_multi_threads(f, host, len);
4438             break;
4439
4440         case RAM_SAVE_FLAG_XBZRLE:
4441             if (load_xbzrle(f, addr, host) < 0) {
4442                 error_report("Failed to decompress XBZRLE page at "
4443                              RAM_ADDR_FMT, addr);
4444                 ret = -EINVAL;
4445                 break;
4446             }
4447             break;
4448         case RAM_SAVE_FLAG_MULTIFD_FLUSH:
4449             multifd_recv_sync_main();
4450             break;
4451         case RAM_SAVE_FLAG_EOS:
4452             /* normal exit */
4453             if (migrate_multifd_flush_after_each_section()) {
4454                 multifd_recv_sync_main();
4455             }
4456             break;
4457         default:
4458             if (flags & RAM_SAVE_FLAG_HOOK) {
4459                 ram_control_load_hook(f, RAM_CONTROL_HOOK, NULL);
4460             } else {
4461                 error_report("Unknown combination of migration flags: 0x%x",
4462                              flags);
4463                 ret = -EINVAL;
4464             }
4465         }
4466         if (!ret) {
4467             ret = qemu_file_get_error(f);
4468         }
4469         if (!ret && host_bak) {
4470             memcpy(host_bak, host, TARGET_PAGE_SIZE);
4471         }
4472     }
4473
4474     ret |= wait_for_decompress_done();
4475     return ret;
4476 }
4477
4478 static int ram_load(QEMUFile *f, void *opaque, int version_id)
4479 {
4480     int ret = 0;
4481     static uint64_t seq_iter;
4482     /*
4483      * If system is running in postcopy mode, page inserts to host memory must
4484      * be atomic
4485      */
4486     bool postcopy_running = postcopy_is_running();
4487
4488     seq_iter++;
4489
4490     if (version_id != 4) {
4491         return -EINVAL;
4492     }
4493
4494     /*
4495      * This RCU critical section can be very long running.
4496      * When RCU reclaims in the code start to become numerous,
4497      * it will be necessary to reduce the granularity of this
4498      * critical section.
4499      */
4500     WITH_RCU_READ_LOCK_GUARD() {
4501         if (postcopy_running) {
4502             /*
4503              * Note!  Here RAM_CHANNEL_PRECOPY is the precopy channel of
4504              * postcopy migration, we have another RAM_CHANNEL_POSTCOPY to
4505              * service fast page faults.
4506              */
4507             ret = ram_load_postcopy(f, RAM_CHANNEL_PRECOPY);
4508         } else {
4509             ret = ram_load_precopy(f);
4510         }
4511     }
4512     trace_ram_load_complete(ret, seq_iter);
4513
4514     return ret;
4515 }
4516
4517 static bool ram_has_postcopy(void *opaque)
4518 {
4519     RAMBlock *rb;
4520     RAMBLOCK_FOREACH_NOT_IGNORED(rb) {
4521         if (ramblock_is_pmem(rb)) {
4522             info_report("Block: %s, host: %p is a nvdimm memory, postcopy"
4523                          "is not supported now!", rb->idstr, rb->host);
4524             return false;
4525         }
4526     }
4527
4528     return migrate_postcopy_ram();
4529 }
4530
4531 /* Sync all the dirty bitmap with destination VM.  */
4532 static int ram_dirty_bitmap_sync_all(MigrationState *s, RAMState *rs)
4533 {
4534     RAMBlock *block;
4535     QEMUFile *file = s->to_dst_file;
4536     int ramblock_count = 0;
4537
4538     trace_ram_dirty_bitmap_sync_start();
4539
4540     RAMBLOCK_FOREACH_NOT_IGNORED(block) {
4541         qemu_savevm_send_recv_bitmap(file, block->idstr);
4542         trace_ram_dirty_bitmap_request(block->idstr);
4543         ramblock_count++;
4544     }
4545
4546     trace_ram_dirty_bitmap_sync_wait();
4547
4548     /* Wait until all the ramblocks' dirty bitmap synced */
4549     while (ramblock_count--) {
4550         qemu_sem_wait(&s->rp_state.rp_sem);
4551     }
4552
4553     trace_ram_dirty_bitmap_sync_complete();
4554
4555     return 0;
4556 }
4557
4558 static void ram_dirty_bitmap_reload_notify(MigrationState *s)
4559 {
4560     qemu_sem_post(&s->rp_state.rp_sem);
4561 }
4562
4563 /*
4564  * Read the received bitmap, revert it as the initial dirty bitmap.
4565  * This is only used when the postcopy migration is paused but wants
4566  * to resume from a middle point.
4567  */
4568 int ram_dirty_bitmap_reload(MigrationState *s, RAMBlock *block)
4569 {
4570     int ret = -EINVAL;
4571     /* from_dst_file is always valid because we're within rp_thread */
4572     QEMUFile *file = s->rp_state.from_dst_file;
4573     unsigned long *le_bitmap, nbits = block->used_length >> TARGET_PAGE_BITS;
4574     uint64_t local_size = DIV_ROUND_UP(nbits, 8);
4575     uint64_t size, end_mark;
4576
4577     trace_ram_dirty_bitmap_reload_begin(block->idstr);
4578
4579     if (s->state != MIGRATION_STATUS_POSTCOPY_RECOVER) {
4580         error_report("%s: incorrect state %s", __func__,
4581                      MigrationStatus_str(s->state));
4582         return -EINVAL;
4583     }
4584
4585     /*
4586      * Note: see comments in ramblock_recv_bitmap_send() on why we
4587      * need the endianness conversion, and the paddings.
4588      */
4589     local_size = ROUND_UP(local_size, 8);
4590
4591     /* Add paddings */
4592     le_bitmap = bitmap_new(nbits + BITS_PER_LONG);
4593
4594     size = qemu_get_be64(file);
4595
4596     /* The size of the bitmap should match with our ramblock */
4597     if (size != local_size) {
4598         error_report("%s: ramblock '%s' bitmap size mismatch "
4599                      "(0x%"PRIx64" != 0x%"PRIx64")", __func__,
4600                      block->idstr, size, local_size);
4601         ret = -EINVAL;
4602         goto out;
4603     }
4604
4605     size = qemu_get_buffer(file, (uint8_t *)le_bitmap, local_size);
4606     end_mark = qemu_get_be64(file);
4607
4608     ret = qemu_file_get_error(file);
4609     if (ret || size != local_size) {
4610         error_report("%s: read bitmap failed for ramblock '%s': %d"
4611                      " (size 0x%"PRIx64", got: 0x%"PRIx64")",
4612                      __func__, block->idstr, ret, local_size, size);
4613         ret = -EIO;
4614         goto out;
4615     }
4616
4617     if (end_mark != RAMBLOCK_RECV_BITMAP_ENDING) {
4618         error_report("%s: ramblock '%s' end mark incorrect: 0x%"PRIx64,
4619                      __func__, block->idstr, end_mark);
4620         ret = -EINVAL;
4621         goto out;
4622     }
4623
4624     /*
4625      * Endianness conversion. We are during postcopy (though paused).
4626      * The dirty bitmap won't change. We can directly modify it.
4627      */
4628     bitmap_from_le(block->bmap, le_bitmap, nbits);
4629
4630     /*
4631      * What we received is "received bitmap". Revert it as the initial
4632      * dirty bitmap for this ramblock.
4633      */
4634     bitmap_complement(block->bmap, block->bmap, nbits);
4635
4636     /* Clear dirty bits of discarded ranges that we don't want to migrate. */
4637     ramblock_dirty_bitmap_clear_discarded_pages(block);
4638
4639     /* We'll recalculate migration_dirty_pages in ram_state_resume_prepare(). */
4640     trace_ram_dirty_bitmap_reload_complete(block->idstr);
4641
4642     /*
4643      * We succeeded to sync bitmap for current ramblock. If this is
4644      * the last one to sync, we need to notify the main send thread.
4645      */
4646     ram_dirty_bitmap_reload_notify(s);
4647
4648     ret = 0;
4649 out:
4650     g_free(le_bitmap);
4651     return ret;
4652 }
4653
4654 static int ram_resume_prepare(MigrationState *s, void *opaque)
4655 {
4656     RAMState *rs = *(RAMState **)opaque;
4657     int ret;
4658
4659     ret = ram_dirty_bitmap_sync_all(s, rs);
4660     if (ret) {
4661         return ret;
4662     }
4663
4664     ram_state_resume_prepare(rs, s->to_dst_file);
4665
4666     return 0;
4667 }
4668
4669 void postcopy_preempt_shutdown_file(MigrationState *s)
4670 {
4671     qemu_put_be64(s->postcopy_qemufile_src, RAM_SAVE_FLAG_EOS);
4672     qemu_fflush(s->postcopy_qemufile_src);
4673 }
4674
4675 static SaveVMHandlers savevm_ram_handlers = {
4676     .save_setup = ram_save_setup,
4677     .save_live_iterate = ram_save_iterate,
4678     .save_live_complete_postcopy = ram_save_complete,
4679     .save_live_complete_precopy = ram_save_complete,
4680     .has_postcopy = ram_has_postcopy,
4681     .state_pending_exact = ram_state_pending_exact,
4682     .state_pending_estimate = ram_state_pending_estimate,
4683     .load_state = ram_load,
4684     .save_cleanup = ram_save_cleanup,
4685     .load_setup = ram_load_setup,
4686     .load_cleanup = ram_load_cleanup,
4687     .resume_prepare = ram_resume_prepare,
4688 };
4689
4690 static void ram_mig_ram_block_resized(RAMBlockNotifier *n, void *host,
4691                                       size_t old_size, size_t new_size)
4692 {
4693     PostcopyState ps = postcopy_state_get();
4694     ram_addr_t offset;
4695     RAMBlock *rb = qemu_ram_block_from_host(host, false, &offset);
4696     Error *err = NULL;
4697
4698     if (ramblock_is_ignored(rb)) {
4699         return;
4700     }
4701
4702     if (!migration_is_idle()) {
4703         /*
4704          * Precopy code on the source cannot deal with the size of RAM blocks
4705          * changing at random points in time - especially after sending the
4706          * RAM block sizes in the migration stream, they must no longer change.
4707          * Abort and indicate a proper reason.
4708          */
4709         error_setg(&err, "RAM block '%s' resized during precopy.", rb->idstr);
4710         migration_cancel(err);
4711         error_free(err);
4712     }
4713
4714     switch (ps) {
4715     case POSTCOPY_INCOMING_ADVISE:
4716         /*
4717          * Update what ram_postcopy_incoming_init()->init_range() does at the
4718          * time postcopy was advised. Syncing RAM blocks with the source will
4719          * result in RAM resizes.
4720          */
4721         if (old_size < new_size) {
4722             if (ram_discard_range(rb->idstr, old_size, new_size - old_size)) {
4723                 error_report("RAM block '%s' discard of resized RAM failed",
4724                              rb->idstr);
4725             }
4726         }
4727         rb->postcopy_length = new_size;
4728         break;
4729     case POSTCOPY_INCOMING_NONE:
4730     case POSTCOPY_INCOMING_RUNNING:
4731     case POSTCOPY_INCOMING_END:
4732         /*
4733          * Once our guest is running, postcopy does no longer care about
4734          * resizes. When growing, the new memory was not available on the
4735          * source, no handler needed.
4736          */
4737         break;
4738     default:
4739         error_report("RAM block '%s' resized during postcopy state: %d",
4740                      rb->idstr, ps);
4741         exit(-1);
4742     }
4743 }
4744
4745 static RAMBlockNotifier ram_mig_ram_notifier = {
4746     .ram_block_resized = ram_mig_ram_block_resized,
4747 };
4748
4749 void ram_mig_init(void)
4750 {
4751     qemu_mutex_init(&XBZRLE.lock);
4752     register_savevm_live("ram", 0, 4, &savevm_ram_handlers, &ram_state);
4753     ram_block_notifier_add(&ram_mig_ram_notifier);
4754 }