123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474 |
- package command
- import (
- "context"
- "fmt"
- "io"
- "io/ioutil"
- "net/http"
- "net/url"
- "os"
- "path/filepath"
- "strconv"
- "strings"
- "sync"
- "time"
- "google.golang.org/grpc"
- "github.com/chrislusf/seaweedfs/weed/operation"
- "github.com/chrislusf/seaweedfs/weed/pb/filer_pb"
- "github.com/chrislusf/seaweedfs/weed/security"
- "github.com/chrislusf/seaweedfs/weed/util"
- "github.com/chrislusf/seaweedfs/weed/wdclient"
- )
- var (
- copy CopyOptions
- waitGroup sync.WaitGroup
- )
- type CopyOptions struct {
- include *string
- replication *string
- collection *string
- ttl *string
- maxMB *int
- masterClient *wdclient.MasterClient
- concurrenctFiles *int
- concurrenctChunks *int
- compressionLevel *int
- grpcDialOption grpc.DialOption
- masters []string
- }
- func init() {
- cmdCopy.Run = runCopy // break init cycle
- cmdCopy.IsDebug = cmdCopy.Flag.Bool("debug", false, "verbose debug information")
- copy.include = cmdCopy.Flag.String("include", "", "pattens of files to copy, e.g., *.pdf, *.html, ab?d.txt, works together with -dir")
- copy.replication = cmdCopy.Flag.String("replication", "", "replication type")
- copy.collection = cmdCopy.Flag.String("collection", "", "optional collection name")
- copy.ttl = cmdCopy.Flag.String("ttl", "", "time to live, e.g.: 1m, 1h, 1d, 1M, 1y")
- copy.maxMB = cmdCopy.Flag.Int("maxMB", 32, "split files larger than the limit")
- copy.concurrenctFiles = cmdCopy.Flag.Int("c", 8, "concurrent file copy goroutines")
- copy.concurrenctChunks = cmdCopy.Flag.Int("concurrentChunks", 8, "concurrent chunk copy goroutines for each file")
- copy.compressionLevel = cmdCopy.Flag.Int("compressionLevel", 9, "local file compression level 1 ~ 9")
- }
- var cmdCopy = &Command{
- UsageLine: "filer.copy file_or_dir1 [file_or_dir2 file_or_dir3] http://localhost:8888/path/to/a/folder/",
- Short: "copy one or a list of files to a filer folder",
- Long: `copy one or a list of files, or batch copy one whole folder recursively, to a filer folder
- It can copy one or a list of files or folders.
- If copying a whole folder recursively:
- All files under the folder and subfolders will be copyed.
- Optional parameter "-include" allows you to specify the file name patterns.
- If "maxMB" is set to a positive number, files larger than it would be split into chunks.
- `,
- }
- func runCopy(cmd *Command, args []string) bool {
- util.LoadConfiguration("security", false)
- if len(args) <= 1 {
- return false
- }
- filerDestination := args[len(args)-1]
- fileOrDirs := args[0 : len(args)-1]
- filerUrl, err := url.Parse(filerDestination)
- if err != nil {
- fmt.Printf("The last argument should be a URL on filer: %v\n", err)
- return false
- }
- urlPath := filerUrl.Path
- if !strings.HasSuffix(urlPath, "/") {
- fmt.Printf("The last argument should be a folder and end with \"/\": %v\n", err)
- return false
- }
- if filerUrl.Port() == "" {
- fmt.Printf("The filer port should be specified.\n")
- return false
- }
- filerPort, parseErr := strconv.ParseUint(filerUrl.Port(), 10, 64)
- if parseErr != nil {
- fmt.Printf("The filer port parse error: %v\n", parseErr)
- return false
- }
- filerGrpcPort := filerPort + 10000
- filerGrpcAddress := fmt.Sprintf("%s:%d", filerUrl.Hostname(), filerGrpcPort)
- copy.grpcDialOption = security.LoadClientTLS(util.GetViper(), "grpc.client")
- ctx := context.Background()
- masters, collection, replication, maxMB, err := readFilerConfiguration(ctx, copy.grpcDialOption, filerGrpcAddress)
- if err != nil {
- fmt.Printf("read from filer %s: %v\n", filerGrpcAddress, err)
- return false
- }
- if *copy.collection == "" {
- *copy.collection = collection
- }
- if *copy.replication == "" {
- *copy.replication = replication
- }
- if *copy.maxMB == 0 {
- *copy.maxMB = int(maxMB)
- }
- copy.masters = masters
- copy.masterClient = wdclient.NewMasterClient(ctx, copy.grpcDialOption, "client", copy.masters)
- go copy.masterClient.KeepConnectedToMaster()
- copy.masterClient.WaitUntilConnected()
- if *cmdCopy.IsDebug {
- util.SetupProfiling("filer.copy.cpu.pprof", "filer.copy.mem.pprof")
- }
- fileCopyTaskChan := make(chan FileCopyTask, *copy.concurrenctFiles)
- go func() {
- defer close(fileCopyTaskChan)
- for _, fileOrDir := range fileOrDirs {
- if err := genFileCopyTask(fileOrDir, urlPath, fileCopyTaskChan); err != nil {
- fmt.Fprintf(os.Stderr, "gen file list error: %v\n", err)
- break
- }
- }
- }()
- for i := 0; i < *copy.concurrenctFiles; i++ {
- waitGroup.Add(1)
- go func() {
- defer waitGroup.Done()
- worker := FileCopyWorker{
- options: ©,
- filerHost: filerUrl.Host,
- filerGrpcAddress: filerGrpcAddress,
- }
- if err := worker.copyFiles(ctx, fileCopyTaskChan); err != nil {
- fmt.Fprintf(os.Stderr, "copy file error: %v\n", err)
- return
- }
- }()
- }
- waitGroup.Wait()
- return true
- }
- func readFilerConfiguration(ctx context.Context, grpcDialOption grpc.DialOption, filerGrpcAddress string) (masters []string, collection, replication string, maxMB uint32, err error) {
- err = withFilerClient(ctx, filerGrpcAddress, grpcDialOption, func(client filer_pb.SeaweedFilerClient) error {
- resp, err := client.GetFilerConfiguration(ctx, &filer_pb.GetFilerConfigurationRequest{})
- if err != nil {
- return fmt.Errorf("get filer %s configuration: %v", filerGrpcAddress, err)
- }
- masters, collection, replication, maxMB = resp.Masters, resp.Collection, resp.Replication, resp.MaxMb
- return nil
- })
- return
- }
- func genFileCopyTask(fileOrDir string, destPath string, fileCopyTaskChan chan FileCopyTask) error {
- fi, err := os.Stat(fileOrDir)
- if err != nil {
- fmt.Fprintf(os.Stderr, "Failed to get stat for file %s: %v\n", fileOrDir, err)
- return nil
- }
- mode := fi.Mode()
- if mode.IsDir() {
- files, _ := ioutil.ReadDir(fileOrDir)
- for _, subFileOrDir := range files {
- if err = genFileCopyTask(fileOrDir+"/"+subFileOrDir.Name(), destPath+fi.Name()+"/", fileCopyTaskChan); err != nil {
- return err
- }
- }
- return nil
- }
- uid, gid := util.GetFileUidGid(fi)
- fileCopyTaskChan <- FileCopyTask{
- sourceLocation: fileOrDir,
- destinationUrlPath: destPath,
- fileSize: fi.Size(),
- fileMode: fi.Mode(),
- uid: uid,
- gid: gid,
- }
- return nil
- }
- type FileCopyWorker struct {
- options *CopyOptions
- filerHost string
- filerGrpcAddress string
- }
- func (worker *FileCopyWorker) copyFiles(ctx context.Context, fileCopyTaskChan chan FileCopyTask) error {
- for task := range fileCopyTaskChan {
- if err := worker.doEachCopy(ctx, task); err != nil {
- return err
- }
- }
- return nil
- }
- type FileCopyTask struct {
- sourceLocation string
- destinationUrlPath string
- fileSize int64
- fileMode os.FileMode
- uid uint32
- gid uint32
- }
- func (worker *FileCopyWorker) doEachCopy(ctx context.Context, task FileCopyTask) error {
- f, err := os.Open(task.sourceLocation)
- if err != nil {
- fmt.Printf("Failed to open file %s: %v\n", task.sourceLocation, err)
- if _, ok := err.(*os.PathError); ok {
- fmt.Printf("skipping %s\n", task.sourceLocation)
- return nil
- }
- return err
- }
- defer f.Close()
- // this is a regular file
- if *worker.options.include != "" {
- if ok, _ := filepath.Match(*worker.options.include, filepath.Base(task.sourceLocation)); !ok {
- return nil
- }
- }
- // find the chunk count
- chunkSize := int64(*worker.options.maxMB * 1024 * 1024)
- chunkCount := 1
- if chunkSize > 0 && task.fileSize > chunkSize {
- chunkCount = int(task.fileSize/chunkSize) + 1
- }
- if chunkCount == 1 {
- return worker.uploadFileAsOne(ctx, task, f)
- }
- return worker.uploadFileInChunks(ctx, task, f, chunkCount, chunkSize)
- }
- func (worker *FileCopyWorker) uploadFileAsOne(ctx context.Context, task FileCopyTask, f *os.File) error {
- // upload the file content
- fileName := filepath.Base(f.Name())
- mimeType := detectMimeType(f)
- var chunks []*filer_pb.FileChunk
- if task.fileSize > 0 {
- // assign a volume
- assignResult, err := operation.Assign(worker.options.masterClient.GetMaster(), worker.options.grpcDialOption, &operation.VolumeAssignRequest{
- Count: 1,
- Replication: *worker.options.replication,
- Collection: *worker.options.collection,
- Ttl: *worker.options.ttl,
- })
- if err != nil {
- fmt.Printf("Failed to assign from %v: %v\n", worker.options.masters, err)
- }
- targetUrl := "http://" + assignResult.Url + "/" + assignResult.Fid
- uploadResult, err := operation.UploadWithLocalCompressionLevel(targetUrl, fileName, f, false, mimeType, nil, assignResult.Auth, *worker.options.compressionLevel)
- if err != nil {
- return fmt.Errorf("upload data %v to %s: %v\n", fileName, targetUrl, err)
- }
- if uploadResult.Error != "" {
- return fmt.Errorf("upload %v to %s result: %v\n", fileName, targetUrl, uploadResult.Error)
- }
- fmt.Printf("uploaded %s to %s\n", fileName, targetUrl)
- chunks = append(chunks, &filer_pb.FileChunk{
- FileId: assignResult.Fid,
- Offset: 0,
- Size: uint64(uploadResult.Size),
- Mtime: time.Now().UnixNano(),
- ETag: uploadResult.ETag,
- })
- fmt.Printf("copied %s => http://%s%s%s\n", fileName, worker.filerHost, task.destinationUrlPath, fileName)
- }
- if err := withFilerClient(ctx, worker.filerGrpcAddress, worker.options.grpcDialOption, func(client filer_pb.SeaweedFilerClient) error {
- request := &filer_pb.CreateEntryRequest{
- Directory: task.destinationUrlPath,
- Entry: &filer_pb.Entry{
- Name: fileName,
- Attributes: &filer_pb.FuseAttributes{
- Crtime: time.Now().Unix(),
- Mtime: time.Now().Unix(),
- Gid: task.gid,
- Uid: task.uid,
- FileSize: uint64(task.fileSize),
- FileMode: uint32(task.fileMode),
- Mime: mimeType,
- Replication: *worker.options.replication,
- Collection: *worker.options.collection,
- TtlSec: int32(util.ParseInt(*worker.options.ttl, 0)),
- },
- Chunks: chunks,
- },
- }
- if err := filer_pb.CreateEntry(ctx, client, request); err != nil {
- return fmt.Errorf("update fh: %v", err)
- }
- return nil
- }); err != nil {
- return fmt.Errorf("upload data %v to http://%s%s%s: %v\n", fileName, worker.filerHost, task.destinationUrlPath, fileName, err)
- }
- return nil
- }
- func (worker *FileCopyWorker) uploadFileInChunks(ctx context.Context, task FileCopyTask, f *os.File, chunkCount int, chunkSize int64) error {
- fileName := filepath.Base(f.Name())
- mimeType := detectMimeType(f)
- chunksChan := make(chan *filer_pb.FileChunk, chunkCount)
- concurrentChunks := make(chan struct{}, *worker.options.concurrenctChunks)
- var wg sync.WaitGroup
- var uploadError error
- fmt.Printf("uploading %s in %d chunks ...\n", fileName, chunkCount)
- for i := int64(0); i < int64(chunkCount) && uploadError == nil; i++ {
- wg.Add(1)
- concurrentChunks <- struct{}{}
- go func(i int64) {
- defer func() {
- wg.Done()
- <-concurrentChunks
- }()
- // assign a volume
- assignResult, err := operation.Assign(worker.options.masterClient.GetMaster(), worker.options.grpcDialOption, &operation.VolumeAssignRequest{
- Count: 1,
- Replication: *worker.options.replication,
- Collection: *worker.options.collection,
- Ttl: *worker.options.ttl,
- })
- if err != nil {
- fmt.Printf("Failed to assign from %v: %v\n", worker.options.masters, err)
- }
- targetUrl := "http://" + assignResult.Url + "/" + assignResult.Fid
- uploadResult, err := operation.Upload(targetUrl,
- fileName+"-"+strconv.FormatInt(i+1, 10),
- io.NewSectionReader(f, i*chunkSize, chunkSize),
- false, "", nil, assignResult.Auth)
- if err != nil {
- uploadError = fmt.Errorf("upload data %v to %s: %v\n", fileName, targetUrl, err)
- return
- }
- if uploadResult.Error != "" {
- uploadError = fmt.Errorf("upload %v to %s result: %v\n", fileName, targetUrl, uploadResult.Error)
- return
- }
- chunksChan <- &filer_pb.FileChunk{
- FileId: assignResult.Fid,
- Offset: i * chunkSize,
- Size: uint64(uploadResult.Size),
- Mtime: time.Now().UnixNano(),
- ETag: uploadResult.ETag,
- }
- fmt.Printf("uploaded %s-%d to %s [%d,%d)\n", fileName, i+1, targetUrl, i*chunkSize, i*chunkSize+int64(uploadResult.Size))
- }(i)
- }
- wg.Wait()
- close(chunksChan)
- var chunks []*filer_pb.FileChunk
- for chunk := range chunksChan {
- chunks = append(chunks, chunk)
- }
- if uploadError != nil {
- var fileIds []string
- for _, chunk := range chunks {
- fileIds = append(fileIds, chunk.FileId)
- }
- operation.DeleteFiles(worker.options.masterClient.GetMaster(), worker.options.grpcDialOption, fileIds)
- return uploadError
- }
- if err := withFilerClient(ctx, worker.filerGrpcAddress, worker.options.grpcDialOption, func(client filer_pb.SeaweedFilerClient) error {
- request := &filer_pb.CreateEntryRequest{
- Directory: task.destinationUrlPath,
- Entry: &filer_pb.Entry{
- Name: fileName,
- Attributes: &filer_pb.FuseAttributes{
- Crtime: time.Now().Unix(),
- Mtime: time.Now().Unix(),
- Gid: task.gid,
- Uid: task.uid,
- FileSize: uint64(task.fileSize),
- FileMode: uint32(task.fileMode),
- Mime: mimeType,
- Replication: *worker.options.replication,
- Collection: *worker.options.collection,
- TtlSec: int32(util.ParseInt(*worker.options.ttl, 0)),
- },
- Chunks: chunks,
- },
- }
- if err := filer_pb.CreateEntry(ctx, client, request); err != nil {
- return fmt.Errorf("update fh: %v", err)
- }
- return nil
- }); err != nil {
- return fmt.Errorf("upload data %v to http://%s%s%s: %v\n", fileName, worker.filerHost, task.destinationUrlPath, fileName, err)
- }
- fmt.Printf("copied %s => http://%s%s%s\n", fileName, worker.filerHost, task.destinationUrlPath, fileName)
- return nil
- }
- func detectMimeType(f *os.File) string {
- head := make([]byte, 512)
- f.Seek(0, io.SeekStart)
- n, err := f.Read(head)
- if err == io.EOF {
- return ""
- }
- if err != nil {
- fmt.Printf("read head of %v: %v\n", f.Name(), err)
- return "application/octet-stream"
- }
- f.Seek(0, io.SeekStart)
- mimeType := http.DetectContentType(head[:n])
- return mimeType
- }
- func withFilerClient(ctx context.Context, filerAddress string, grpcDialOption grpc.DialOption, fn func(filer_pb.SeaweedFilerClient) error) error {
- return util.WithCachedGrpcClient(ctx, func(ctx context.Context, clientConn *grpc.ClientConn) error {
- client := filer_pb.NewSeaweedFilerClient(clientConn)
- return fn(client)
- }, filerAddress, grpcDialOption)
- }
|