偷偷摘套内射激情视频,久久精品99国产国产精,中文字幕无线乱码人妻,中文在线中文a,性爽19p

SpringBoot 如何實(shí)現(xiàn)零拷貝:深度解析零拷貝技術(shù)

系統(tǒng) Linux
如果服務(wù)端要提供文件傳輸?shù)墓δ埽覀兡芟氲降淖詈?jiǎn)單的方式是:將磁盤(pán)上的文件讀取出來(lái),然后通過(guò)網(wǎng)絡(luò)協(xié)議發(fā)送給客戶端。傳統(tǒng) I/O 的工作方式是,數(shù)據(jù)讀取和寫(xiě)入是從用戶空間到內(nèi)核空間來(lái)回復(fù)制,而內(nèi)核空間的數(shù)據(jù)是通過(guò)操作系統(tǒng)層面的 I/O 接口從磁盤(pán)讀取或?qū)懭搿?/div>

前言

一、為什么引入零拷貝?

如果服務(wù)端要提供文件傳輸?shù)墓δ埽覀兡芟氲降淖詈?jiǎn)單的方式是:將磁盤(pán)上的文件讀取出來(lái),然后通過(guò)網(wǎng)絡(luò)協(xié)議發(fā)送給客戶端。

傳統(tǒng) I/O 的工作方式是,數(shù)據(jù)讀取和寫(xiě)入是從用戶空間到內(nèi)核空間來(lái)回復(fù)制,而內(nèi)核空間的數(shù)據(jù)是通過(guò)操作系統(tǒng)層面的 I/O 接口從磁盤(pán)讀取或?qū)懭搿?/p>

C:

read(file, tmp_buf, len);
write(socket, tmp_buf, len);

Java:

// 傳統(tǒng)文件讀取和發(fā)送的偽代碼表示
public class TraditionalFileTransfer {
    public void transferFile(File file, Socket socket) throws IOException {
        byte[] buffer = new byte[8192];  // 用戶空間緩沖區(qū)
        // 1. 從磁盤(pán)讀取到內(nèi)核緩沖區(qū)(DMA拷貝)
        // 2. 從內(nèi)核緩沖區(qū)拷貝到用戶緩沖區(qū)(CPU拷貝)
        FileInputStream fis = new FileInputStream(file);
        int bytesRead;
        while ((bytesRead = fis.read(buffer)) != -1) {
            // 3. 從用戶緩沖區(qū)拷貝到Socket緩沖區(qū)(CPU拷貝)
            // 4. 從Socket緩沖區(qū)拷貝到網(wǎng)卡緩沖區(qū)(DMA拷貝)
            socket.getOutputStream().write(buffer, 0, bytesRead);
        }
    }
}

代碼很簡(jiǎn)單,雖然就兩行代碼,但是這里面發(fā)生了不少的事情。

圖片圖片

首先,期間共發(fā)生了 4 次用戶態(tài)與內(nèi)核態(tài)的上下文切換,因?yàn)榘l(fā)生了兩次系統(tǒng)調(diào)用,一次是 read() ,一次是 write(),每次系統(tǒng)調(diào)用都得先從用戶態(tài)切換到內(nèi)核態(tài),等內(nèi)核完成任務(wù)后,再?gòu)膬?nèi)核態(tài)切換回用戶態(tài)。

上下文切換到成本并不小,一次切換需要耗時(shí)幾十納秒到幾微秒,雖然時(shí)間看上去很短,但是在高并發(fā)的場(chǎng)景下,這類時(shí)間容易被累積和放大,從而影響系統(tǒng)的性能。

其次,還發(fā)生了 4 次數(shù)據(jù)拷貝,其中兩次是 DMA 的拷貝,另外兩次則是通過(guò) CPU 拷貝的,下面說(shuō)一下這個(gè)過(guò)程:

  • 第一次拷貝,把磁盤(pán)上的數(shù)據(jù)拷貝到操作系統(tǒng)內(nèi)核的緩沖區(qū)里,這個(gè)拷貝的過(guò)程是通過(guò) DMA 搬運(yùn)的。
  • 第二次拷貝,把內(nèi)核緩沖區(qū)的數(shù)據(jù)拷貝到用戶的緩沖區(qū)里,于是我們應(yīng)用程序就可以使用這部分?jǐn)?shù)據(jù)了,這個(gè)拷貝到過(guò)程是由 CPU 完成的。
  • 第三次拷貝,把剛才拷貝到用戶的緩沖區(qū)里的數(shù)據(jù),再拷貝到內(nèi)核的 socket 的緩沖區(qū)里,這個(gè)過(guò)程依然還是由 CPU 搬運(yùn)的。
  • 第四次拷貝,把內(nèi)核的 socket 緩沖區(qū)里的數(shù)據(jù),拷貝到網(wǎng)卡的緩沖區(qū)里,這個(gè)過(guò)程又是由 DMA 搬運(yùn)的。

我們回過(guò)頭看這個(gè)文件傳輸?shù)倪^(guò)程,我們只是搬運(yùn)一份數(shù)據(jù),結(jié)果卻搬運(yùn)了 4 次,過(guò)多的數(shù)據(jù)拷貝無(wú)疑會(huì)消耗 CPU 資源,大大降低了系統(tǒng)性能。

這種簡(jiǎn)單又傳統(tǒng)的文件傳輸方式,存在冗余的上文切換和數(shù)據(jù)拷貝,在高并發(fā)系統(tǒng)里是非常糟糕的,多了很多不必要的開(kāi)銷,會(huì)嚴(yán)重影響系統(tǒng)性能。

所以,要想提高文件傳輸?shù)男阅?,就需要減少「用戶態(tài)與內(nèi)核態(tài)的上下文切換」和「內(nèi)存拷貝」的次數(shù)。

零拷貝原理

一、mmap + write 實(shí)現(xiàn)零拷貝

在前面我們知道,read() 系統(tǒng)調(diào)用的過(guò)程中會(huì)把內(nèi)核緩沖區(qū)的數(shù)據(jù)拷貝到用戶的緩沖區(qū)里,于是為了減少這一步開(kāi)銷,我們可以用 mmap() 替換 read() 系統(tǒng)調(diào)用函數(shù)。

buf = mmap(file, len);
write(sockfd, buf, len);

mmap() 系統(tǒng)調(diào)用函數(shù)會(huì)直接把內(nèi)核緩沖區(qū)里的數(shù)據(jù)「映射」到用戶空間,這樣,操作系統(tǒng)內(nèi)核與用戶空間就不需要再進(jìn)行任何的數(shù)據(jù)拷貝操作。

圖片圖片

具體過(guò)程如下:

  • 應(yīng)用進(jìn)程調(diào)用了 mmap() 后,DMA 會(huì)把磁盤(pán)的數(shù)據(jù)拷貝到內(nèi)核的緩沖區(qū)里。接著,應(yīng)用進(jìn)程跟操作系統(tǒng)內(nèi)核「共享」這個(gè)緩沖區(qū);
  • 應(yīng)用進(jìn)程再調(diào)用 write(),操作系統(tǒng)直接將內(nèi)核緩沖區(qū)的數(shù)據(jù)拷貝到 socket 緩沖區(qū)中,這一切都發(fā)生在內(nèi)核態(tài),由 CPU 來(lái)搬運(yùn)數(shù)據(jù);
  • 最后,把內(nèi)核的 socket 緩沖區(qū)里的數(shù)據(jù),拷貝到網(wǎng)卡的緩沖區(qū)里,這個(gè)過(guò)程是由 DMA 搬運(yùn)的。

我們可以得知,通過(guò)使用 mmap() 來(lái)代替 read(), 可以減少一次數(shù)據(jù)拷貝的過(guò)程。

但這還不是最理想的零拷貝,因?yàn)槿匀恍枰ㄟ^(guò) CPU 把內(nèi)核緩沖區(qū)的數(shù)據(jù)拷貝到 socket 緩沖區(qū)里,而且仍然需要 4 次上下文切換,因?yàn)橄到y(tǒng)調(diào)用還是 2 次。

二、sendfile 實(shí)現(xiàn)零拷貝

在 Linux 內(nèi)核版本 2.1 中,提供了一個(gè)專門(mén)發(fā)送文件的系統(tǒng)調(diào)用函數(shù) sendfile(),函數(shù)形式如下:

#include <sys/socket.h>
ssize_t sendfile(int out_fd, int in_fd, off_t *offset, size_t count);

它的前兩個(gè)參數(shù)分別是目的端和源端的文件描述符,后面兩個(gè)參數(shù)是源端的偏移量和復(fù)制數(shù)據(jù)的長(zhǎng)度,返回值是實(shí)際復(fù)制數(shù)據(jù)的長(zhǎng)度。

首先,它可以替代前面的 read() 和 write() 這兩個(gè)系統(tǒng)調(diào)用,這樣就可以減少一次系統(tǒng)調(diào)用,也就減少了 2 次上下文切換的開(kāi)銷。

其次,該系統(tǒng)調(diào)用,可以直接把內(nèi)核緩沖區(qū)里的數(shù)據(jù)拷貝到 socket 緩沖區(qū)里,不再拷貝到用戶態(tài),這樣就只有 2 次上下文切換,和 3 次數(shù)據(jù)拷貝。如下圖:

圖片圖片


但是這還不是真正的零拷貝技術(shù),如果網(wǎng)卡支持 SG-DMA(The Scatter-Gather Direct Memory Access)技術(shù)(和普通的 DMA 有所不同),我們可以進(jìn)一步減少通過(guò) CPU 把內(nèi)核緩沖區(qū)里的數(shù)據(jù)拷貝到 socket 緩沖區(qū)的過(guò)程。

你可以在你的 Linux 系統(tǒng)通過(guò)下面這個(gè)命令,查看網(wǎng)卡是否支持 scatter-gather 特性:

$ ethtool -k eth0 | grep scatter-gather
scatter-gather: on

于是,從 Linux 內(nèi)核 2.4 版本開(kāi)始起,對(duì)于支持網(wǎng)卡支持 SG-DMA 技術(shù)的情況下, sendfile() 系統(tǒng)調(diào)用的過(guò)程發(fā)生了點(diǎn)變化,具體過(guò)程如下:

  • 第一步,通過(guò) DMA 將磁盤(pán)上的數(shù)據(jù)拷貝到內(nèi)核緩沖區(qū)里;
  • 第二步,緩沖區(qū)描述符和數(shù)據(jù)長(zhǎng)度傳到 socket 緩沖區(qū),這樣網(wǎng)卡的 SG-DMA 控制器就可以直接將內(nèi)核緩存中的數(shù)據(jù)拷貝到網(wǎng)卡的緩沖區(qū)里,此過(guò)程不需要將數(shù)據(jù)從操作系統(tǒng)內(nèi)核緩沖區(qū)拷貝到 socket 緩沖區(qū)中,這樣就減少了一次數(shù)據(jù)拷貝;

所以,這個(gè)過(guò)程之中,只進(jìn)行了 2 次數(shù)據(jù)拷貝,如下圖:

圖片圖片

這就是所謂的零拷貝(Zero-copy)技術(shù),因?yàn)槲覀儧](méi)有在內(nèi)存層面去拷貝數(shù)據(jù),也就是說(shuō)全程沒(méi)有通過(guò) CPU 來(lái)搬運(yùn)數(shù)據(jù),所有的數(shù)據(jù)都是通過(guò) DMA 來(lái)進(jìn)行傳輸?shù)摹?/p>

零拷貝技術(shù)的文件傳輸方式相比傳統(tǒng)文件傳輸?shù)姆绞剑瑴p少了 2 次上下文切換和數(shù)據(jù)拷貝次數(shù),只需要 2 次上下文切換和數(shù)據(jù)拷貝次數(shù),就可以完成文件的傳輸,而且 2 次的數(shù)據(jù)拷貝過(guò)程,都不需要通過(guò) CPU,2 次都是由 DMA 來(lái)搬運(yùn)。

SpringBoot 零拷貝實(shí)現(xiàn)

一、基于NIO的FileChannel實(shí)現(xiàn)

核心文件傳輸服務(wù)

@Service
@Slf4j
public class ZeroCopyFileService {


    private static final int BUFFER_SIZE = 8192;


    /**
     * 使用FileChannel.transferTo實(shí)現(xiàn)零拷貝文件傳輸
     * 這是最高效的零拷貝實(shí)現(xiàn)方式
     */
    public void transferFileWithZeroCopy(File file, ServletResponse response) 
            throws IOException {


        try (FileChannel fileChannel = new FileInputStream(file).getChannel();
             WritableByteChannel outputChannel = Channels.newChannel(response.getOutputStream())) {


            long position = 0;
            long fileSize = fileChannel.size();


            // 使用transferTo進(jìn)行零拷貝傳輸
            while (position < fileSize) {
                long transferred = fileChannel.transferTo(position, fileSize - position, outputChannel);
                if (transferred <= 0) {
                    break;
                }
                position += transferred;
            }


            log.debug("零拷貝文件傳輸完成: {}, 文件大小: {} bytes", file.getName(), fileSize);


        } catch (IOException e) {
            log.error("零拷貝文件傳輸失敗: {}", file.getName(), e);
            throw e;
        }
    }


    /**
     * 使用MappedByteBuffer實(shí)現(xiàn)內(nèi)存映射文件傳輸
     * 適合大文件的分塊處理
     */
    public void transferFileWithMmap(File file, ServletResponse response, 
                                   long chunkSize) throws IOException {


        if (chunkSize <= 0) {
            chunkSize = 1024 * 1024; // 默認(rèn)1MB分塊
        }


        try (FileChannel fileChannel = new RandomAccessFile(file, "r").getChannel()) {
            long fileSize = fileChannel.size();
            long position = 0;


            while (position < fileSize) {
                long size = Math.min(chunkSize, fileSize - position);


                // 創(chuàng)建內(nèi)存映射
                MappedByteBuffer mappedBuffer = fileChannel.map(
                    FileChannel.MapMode.READ_ONLY, position, size);


                // 通過(guò)Channel發(fā)送映射的緩沖區(qū)
                WritableByteChannel outputChannel = Channels.newChannel(response.getOutputStream());
                while (mappedBuffer.hasRemaining()) {
                    outputChannel.write(mappedBuffer);
                }


                // 清理映射
                clean(mappedBuffer);
                position += size;
            }


            log.debug("內(nèi)存映射文件傳輸完成: {}, 文件大小: {} bytes", file.getName(), fileSize);
        }
    }


    /**
     * 清理MappedByteBuffer
     */
    private void clean(MappedByteBuffer buffer) {
        if (buffer == null || !buffer.isDirect()) return;


        try {
            Method cleanerMethod = buffer.getClass().getMethod("cleaner");
            cleanerMethod.setAccessible(true);
            Object cleaner = cleanerMethod.invoke(buffer);
            if (cleaner != null) {
                Method cleanMethod = cleaner.getClass().getMethod("clean");
                cleanMethod.setAccessible(true);
                cleanMethod.invoke(cleaner);
            }
        } catch (Exception e) {
            log.warn("清理MappedByteBuffer失敗", e);
        }
    }
}

二、Spring Web 零拷貝控制器實(shí)現(xiàn)

RESTful文件傳輸接口

@RestController
@RequestMapping("/api/file")
@Slf4j
public class ZeroCopyFileController {


    @Autowired
    private ZeroCopyFileService zeroCopyFileService;


    @Value("${file.upload.dir:/tmp/uploads}")
    private String uploadDir;


    /**
     * 零拷貝文件下載
     */
    @GetMapping("/download/{filename}")
    public void downloadFile(@PathVariable String filename, 
                           HttpServletRequest request,
                           HttpServletResponse response) throws IOException {


        File file = new File(uploadDir, filename);
        if (!file.exists() || !file.isFile()) {
            response.sendError(HttpStatus.NOT_FOUND.value(), "文件不存在");
            return;
        }


        // 設(shè)置響應(yīng)頭
        setupFileDownloadHeaders(response, file, filename);


        try {
            // 使用零拷貝傳輸文件
            zeroCopyFileService.transferFileWithZeroCopy(file, response);


            log.info("文件下載完成: {}, 大小: {} bytes, 客戶端: {}", 
                    filename, file.length(), getClientIp(request));


        } catch (IOException e) {
            log.error("文件下載失敗: {}", filename, e);
            if (!response.isCommitted()) {
                response.sendError(HttpStatus.INTERNAL_SERVER_ERROR.value(), 
                                 "文件下載失敗");
            }
        }
    }


    /**
     * 大文件分塊下載(支持?jǐn)帱c(diǎn)續(xù)傳)
     */
    @GetMapping("/download/{filename}/chunked")
    public void downloadFileChunked(@PathVariable String filename,
                                  @RequestHeader(value = "Range", required = false) String rangeHeader,
                                  HttpServletRequest request,
                                  HttpServletResponse response) throws IOException {


        File file = new File(uploadDir, filename);
        if (!file.exists() || !file.isFile()) {
            response.sendError(HttpStatus.NOT_FOUND.value(), "文件不存在");
            return;
        }


        long fileLength = file.length();
        long start = 0;
        long end = fileLength - 1;


        // 處理范圍請(qǐng)求(斷點(diǎn)續(xù)傳)
        if (rangeHeader != null && rangeHeader.startsWith("bytes=")) {
            String[] ranges = rangeHeader.substring(6).split("-");
            start = Long.parseLong(ranges[0]);
            if (ranges.length > 1) {
                end = Long.parseLong(ranges[1]);
            }
            end = Math.min(end, fileLength - 1);


            response.setStatus(HttpStatus.PARTIAL_CONTENT.value());
            response.setHeader("Content-Range", 
                String.format("bytes %d-%d/%d", start, end, fileLength));
        }


        long contentLength = end - start + 1;
        setupFileDownloadHeaders(response, file, filename);
        response.setContentLengthLong(contentLength);


        // 使用內(nèi)存映射進(jìn)行分塊傳輸
        try (RandomAccessFile randomAccessFile = new RandomAccessFile(file, "r");
             FileChannel fileChannel = randomAccessFile.getChannel()) {


            // 定位到指定位置
            WritableByteChannel outputChannel = Channels.newChannel(response.getOutputStream());
            fileChannel.transferTo(start, contentLength, outputChannel);


            log.info("文件分塊下載完成: {} [{} - {}], 客戶端: {}", 
                    filename, start, end, getClientIp(request));


        } catch (IOException e) {
            log.error("文件分塊下載失敗: {}", filename, e);
            if (!response.isCommitted()) {
                response.sendError(HttpStatus.INTERNAL_SERVER_ERROR.value(), 
                                 "文件下載失敗");
            }
        }
    }


    /**
     * 設(shè)置文件下載響應(yīng)頭
     */
    private void setupFileDownloadHeaders(HttpServletResponse response, 
                                        File file, String filename) {
        // 內(nèi)容類型
        String contentType = determineContentType(filename);
        response.setContentType(contentType);


        // 內(nèi)容處置
        String encodedFilename = URLEncoder.encode(filename, StandardCharsets.UTF_8)
            .replaceAll("\\+", "%20");
        response.setHeader("Content-Disposition", 
            "attachment; filename*=UTF-8''" + encodedFilename);


        // 緩存控制
        response.setHeader("Cache-Control", "private, max-age=300");
        response.setHeader("Pragma", "private");
        response.setDateHeader("Expires", 
            System.currentTimeMillis() + 300 * 1000);


        // 文件大小
        response.setContentLengthLong(file.length());


        // 支持?jǐn)帱c(diǎn)續(xù)傳
        response.setHeader("Accept-Ranges", "bytes");
    }


    /**
     * 根據(jù)文件名確定內(nèi)容類型
     */
    private String determineContentType(String filename) {
        String extension = FilenameUtils.getExtension(filename).toLowerCase();
        switch (extension) {
            case "pdf": return "application/pdf";
            case "jpg": case "jpeg": return "image/jpeg";
            case "png": return "image/png";
            case "txt": return "text/plain";
            case "zip": return "application/zip";
            default: return "application/octet-stream";
        }
    }


    /**
     * 獲取客戶端IP
     */
    private String getClientIp(HttpServletRequest request) {
        String xForwardedFor = request.getHeader("X-Forwarded-For");
        if (xForwardedFor != null && !xForwardedFor.isEmpty()) {
            return xForwardedFor.split(",")[0];
        }
        return request.getRemoteAddr();
    }
}

三、高級(jí)特性:異步零拷貝處理

異步文件處理器

@Component
@Slf4j
public class AsyncZeroCopyProcessor {


    @Autowired
    private ZeroCopyFileService zeroCopyFileService;


    private final ExecutorService asyncExecutor = Executors.newFixedThreadPool(
        Runtime.getRuntime().availableProcessors(),
        new ThreadFactoryBuilder()
            .setNameFormat("zero-copy-async-%d")
            .setDaemon(true)
            .build()
    );


    /**
     * 異步零拷貝文件處理
     */
    public CompletableFuture<Void> processFileAsync(File file, 
                                                   ServletResponse response) {
        return CompletableFuture.runAsync(() -> {
            try {
                zeroCopyFileService.transferFileWithZeroCopy(file, response);
            } catch (IOException e) {
                log.error("異步文件處理失敗: {}", file.getName(), e);
                throw new CompletionException(e);
            }
        }, asyncExecutor);
    }


    /**
     * 批量文件異步傳輸
     */
    public CompletableFuture<Void> processBatchFilesAsync(List<File> files,
                                                         ServletResponse response) {
        List<CompletableFuture<Void>> futures = files.stream()
            .map(file -> processFileAsync(file, response))
            .collect(Collectors.toList());


        return CompletableFuture.allOf(
            futures.toArray(new CompletableFuture[0])
        );
    }


    @PreDestroy
    public void shutdown() {
        asyncExecutor.shutdown();
        try {
            if (!asyncExecutor.awaitTermination(5, TimeUnit.SECONDS)) {
                asyncExecutor.shutdownNow();
            }
        } catch (InterruptedException e) {
            asyncExecutor.shutdownNow();
            Thread.currentThread().interrupt();
        }
    }
}

四、Netty 零拷貝集成

Netty文件服務(wù)器實(shí)現(xiàn)

@Component
@Slf4j
public class NettyZeroCopyServer {


    @Value("${netty.server.port:8080}")
    private int port;


    private EventLoopGroup bossGroup;
    private EventLoopGroup workerGroup;
    private ChannelFuture channelFuture;


    /**
     * 啟動(dòng)Netty零拷貝文件服務(wù)器
     */
    @PostConstruct
    public void start() throws InterruptedException {
        bossGroup = new NioEventLoopGroup(1);
        workerGroup = new NioEventLoopGroup();


        try {
            ServerBootstrap bootstrap = new ServerBootstrap();
            bootstrap.group(bossGroup, workerGroup)
                .channel(NioServerSocketChannel.class)
                .childHandler(new ChannelInitializer<SocketChannel>() {
                    @Override
                    protected void initChannel(SocketChannel ch) {
                        ChannelPipeline pipeline = ch.pipeline();
                        pipeline.addLast(new HttpServerCodec());
                        pipeline.addLast(new HttpObjectAggregator(65536));
                        pipeline.addLast(new ZeroCopyFileHandler());
                    }
                })
                .option(ChannelOption.SO_BACKLOG, 128)
                .childOption(ChannelOption.SO_KEEPALIVE, true);


            channelFuture = bootstrap.bind(port).sync();
            log.info("Netty零拷貝文件服務(wù)器啟動(dòng)成功,端口: {}", port);


        } catch (Exception e) {
            log.error("Netty服務(wù)器啟動(dòng)失敗", e);
            stop();
            throw e;
        }
    }


    /**
     * Netty零拷貝文件處理器
     */
    private static class ZeroCopyFileHandler extends SimpleChannelInboundHandler<FullHttpRequest> {


        @Override
        protected void channelRead0(ChannelHandlerContext ctx, FullHttpRequest request) {
            if (!request.decoderResult().isSuccess()) {
                sendError(ctx, HttpResponseStatus.BAD_REQUEST);
                return;
            }


            if (request.method() != HttpMethod.GET) {
                sendError(ctx, HttpResponseStatus.METHOD_NOT_ALLOWED);
                return;
            }


            String uri = request.uri();
            if (!uri.startsWith("/file/")) {
                sendError(ctx, HttpResponseStatus.NOT_FOUND);
                return;
            }


            String filename = uri.substring(6); // 去掉"/file/"
            File file = new File("/data/files", filename);


            if (!file.exists() || file.isDirectory()) {
                sendError(ctx, HttpResponseStatus.NOT_FOUND);
                return;
            }


            // 使用零拷貝發(fā)送文件
            try {
                RandomAccessFile raf = new RandomAccessFile(file, "r");
                long fileLength = raf.length();


                HttpResponse response = new DefaultHttpResponse(HttpVersion.HTTP_1_1, HttpResponseStatus.OK);
                HttpUtil.setContentLength(response, fileLength);
                response.headers().set(HttpHeaderNames.CONTENT_TYPE, "application/octet-stream");


                // 設(shè)置文件下載頭
                String encodedFilename = URLEncoder.encode(filename, StandardCharsets.UTF_8)
                    .replaceAll("\\+", "%20");
                response.headers().set(HttpHeaderNames.CONTENT_DISPOSITION,
                    "attachment; filename*=UTF-8''" + encodedFilename);


                // 寫(xiě)入HTTP響應(yīng)頭
                ctx.write(response);


                // 使用零拷貝發(fā)送文件內(nèi)容
                FileRegion region = new DefaultFileRegion(raf.getChannel(), 0, fileLength);
                ctx.write(region, ctx.newProgressivePromise())
                   .addListener(new ChannelFutureListener() {
                       @Override
                       public void operationComplete(ChannelFuture future) {
                           if (!future.isSuccess()) {
                               log.error("文件傳輸失敗: {}", filename, future.cause());
                           }
                           try {
                               raf.close();
                           } catch (IOException e) {
                               log.warn("關(guān)閉文件失敗: {}", filename, e);
                           }
                       }
                   });


                // 寫(xiě)入結(jié)束標(biāo)記
                ChannelFuture lastContentFuture = ctx.writeAndFlush(LastHttpContent.EMPTY_LAST_CONTENT);
                lastContentFuture.addListener(ChannelFutureListener.CLOSE);


                log.debug("Netty零拷貝文件發(fā)送完成: {}, 大小: {} bytes", filename, fileLength);


            } catch (Exception e) {
                log.error("文件處理失敗: {}", filename, e);
                sendError(ctx, HttpResponseStatus.INTERNAL_SERVER_ERROR);
            }
        }


        private void sendError(ChannelHandlerContext ctx, HttpResponseStatus status) {
            FullHttpResponse response = new DefaultFullHttpResponse(
                HttpVersion.HTTP_1_1, status);
            response.headers().set(HttpHeaderNames.CONTENT_TYPE, "text/plain; charset=UTF-8");
            ctx.writeAndFlush(response).addListener(ChannelFutureListener.CLOSE);
        }


        @Override
        public void exceptionCaught(ChannelHandlerContext ctx, Throwable cause) {
            log.error("通道處理異常", cause);
            ctx.close();
        }
    }


    /**
     * 停止服務(wù)器
     */
    @PreDestroy
    public void stop() {
        if (channelFuture != null) {
            channelFuture.channel().close();
        }
        if (bossGroup != null) {
            bossGroup.shutdownGracefully();
        }
        if (workerGroup != null) {
            workerGroup.shutdownGracefully();
        }
        log.info("Netty零拷貝文件服務(wù)器已停止");
    }
}

最佳實(shí)踐與注意事項(xiàng)

一、配置優(yōu)化

零拷貝相關(guān)配置

# application.yml
server:
  servlet:
    multipart:
      max-file-size: 10MB
      max-request-size: 10MB
  tomcat:
    max-swallow-size: 10MB
    max-http-form-post-size: 10MB


# 自定義零拷貝配置
zerocopy:
  enabled: true
  buffer-size: 8192
  chunk-size: 1MB
  max-file-size: 1GB
  async-enabled: true
  async-threads: 4

二、內(nèi)存管理優(yōu)化

直接內(nèi)存監(jiān)控與管理

@Component
@Slf4j
public class DirectMemoryMonitor {


    private final BufferPoolMXBean directBufferPool;


    public DirectMemoryMonitor() {
        this.directBufferPool = ManagementFactory.getPlatformMXBeans(BufferPoolMXBean.class)
            .stream()
            .filter(pool -> "direct".equals(pool.getName()))
            .findFirst()
            .orElse(null);
    }


    /**
     * 監(jiān)控直接內(nèi)存使用情況
     */
    @Scheduled(fixedRate = 30000)
    public void monitorDirectMemory() {
        if (directBufferPool != null) {
            long used = directBufferPool.getMemoryUsed();
            long total = directBufferPool.getTotalCapacity();
            long count = directBufferPool.getCount();


            if (used > total * 0.8) {
                log.warn("直接內(nèi)存使用率過(guò)高: {}/{} bytes ({} buffers)", used, total, count);
            }


            log.debug("直接內(nèi)存使用: {}/{} bytes, 緩沖區(qū)數(shù)量: {}", used, total, count);
        }
    }


    /**
     * 獲取直接內(nèi)存統(tǒng)計(jì)
     */
    public DirectMemoryStats getDirectMemoryStats() {
        if (directBufferPool == null) {
            return null;
        }


        DirectMemoryStats stats = new DirectMemoryStats();
        stats.setUsedMemory(directBufferPool.getMemoryUsed());
        stats.setTotalCapacity(directBufferPool.getTotalCapacity());
        stats.setBufferCount(directBufferPool.getCount());
        stats.setUsagePercentage((double) stats.getUsedMemory() / stats.getTotalCapacity() * 100);


        return stats;
    }


    @Data
    public static class DirectMemoryStats {
        private long usedMemory;
        private long totalCapacity;
        private long bufferCount;
        private double usagePercentage;
    }
}


責(zé)任編輯:武曉燕 來(lái)源: 小林聊編程
相關(guān)推薦

2022-05-05 13:57:43

Buffer設(shè)備MYSQL

2024-06-24 00:09:00

零拷貝技術(shù)MMapsendFile

2023-07-29 13:45:30

了不起 Java極

2021-08-26 06:57:53

零拷貝技術(shù)磁盤(pán)

2020-07-06 15:10:05

Linux拷貝代碼

2020-07-23 15:40:54

Linux零拷貝文件

2022-09-27 13:34:49

splice零拷貝原理

2022-05-16 08:22:37

零拷貝Netty

2024-12-04 14:45:14

零拷貝技術(shù)CPU 拷貝Zero-copy

2020-02-28 19:10:40

Linux零拷貝原理

2024-11-28 10:40:26

零拷貝技術(shù)系統(tǒng)

2021-03-12 13:57:13

零拷貝技術(shù)

2025-10-14 07:53:20

零拷貝CPUI/O 性能

2025-07-22 03:15:00

SpringFlight零拷貝

2020-10-12 06:33:18

Zero-Copy零拷貝CPU

2024-06-07 08:10:14

Netty操作系統(tǒng)零拷貝

2020-11-27 09:20:56

零拷貝底層技術(shù)

2024-09-20 08:36:43

零拷貝數(shù)據(jù)傳輸DMA

2024-03-22 06:56:24

零拷貝技術(shù)數(shù)據(jù)傳輸數(shù)據(jù)拷貝

2024-07-31 08:28:37

DMAIOMMap
點(diǎn)贊
收藏

51CTO技術(shù)棧公眾號(hào)