diff --git a/.golangci.yml b/.golangci.yml index f77b17e7c..eedba5333 100644 --- a/.golangci.yml +++ b/.golangci.yml @@ -23,6 +23,9 @@ issues: - path: tests/e2e linters: - gosec + - path: tests/sanity + linters: + - gosec linters-settings: revive: rules: diff --git a/Makefile b/Makefile index 044395700..04c5aceac 100644 --- a/Makefile +++ b/Makefile @@ -127,6 +127,10 @@ cluster/uninstall: bin/helm bin/aws ## E2E targets # Targets to run e2e tests +.PHONY: sanity +sanity: + go test -v -race ./tests/sanity/... + .PHONY: e2e/single-az e2e/single-az: bin/helm bin/ginkgo AWS_AVAILABILITY_ZONES=us-west-2a \ diff --git a/go.mod b/go.mod index a7d12b2e0..1e550759a 100644 --- a/go.mod +++ b/go.mod @@ -87,6 +87,7 @@ require ( github.com/josharian/intern v1.0.0 // indirect github.com/json-iterator/go v1.1.12 // indirect github.com/klauspost/compress v1.17.11 // indirect + github.com/kubernetes-csi/csi-test/v5 v5.3.1 github.com/kylelemons/godebug v1.1.0 // indirect github.com/mailru/easyjson v0.9.0 // indirect github.com/moby/spdystream v0.5.0 // indirect diff --git a/go.sum b/go.sum index 7a1134086..3023a30e9 100644 --- a/go.sum +++ b/go.sum @@ -229,6 +229,8 @@ github.com/kubernetes-csi/csi-proxy/client v1.1.3 h1:FdGU7NtxGhQX2wTfnuscmThG920 github.com/kubernetes-csi/csi-proxy/client v1.1.3/go.mod h1:SfK4HVKQdMH5KrffivddAWgX5hl3P5KmnuOTBbDNboU= github.com/kubernetes-csi/csi-proxy/v2 v2.0.0-alpha.1 h1:tVPvlL5N5X598hrO3g9rhyoi6h0LP4RpSJlGHItsbEE= github.com/kubernetes-csi/csi-proxy/v2 v2.0.0-alpha.1/go.mod h1:pacx+PW7lLlu6kAvpr8Lgq/5fdiAsKxOtXXFHMaLMb8= +github.com/kubernetes-csi/csi-test/v5 v5.3.1 h1:Wiukp1In+kif+BFo6q2ExjgB+MbrAz4jZWzGfijypuY= +github.com/kubernetes-csi/csi-test/v5 v5.3.1/go.mod h1:7hA2cSYJ6T8CraEZPA6zqkLZwemjBD54XAnPsPC3VpA= github.com/kubernetes-csi/external-snapshotter/client/v4 v4.2.0 h1:nHHjmvjitIiyPlUHk/ofpgvBcNcawJLtf4PYHORLjAA= github.com/kubernetes-csi/external-snapshotter/client/v4 v4.2.0/go.mod h1:YBCo4DoEeDndqvAn6eeu0vWM7QdXmHEeI9cFWplmBys= github.com/kylelemons/godebug v1.1.0 h1:RPNrshWIDI6G2gRW9EHilWtl7Z6Sb1BR0xunSBf0SNc= diff --git a/pkg/driver/controller_modify_volume.go b/pkg/driver/controller_modify_volume.go index 10f40b8c7..1a1608094 100644 --- a/pkg/driver/controller_modify_volume.go +++ b/pkg/driver/controller_modify_volume.go @@ -150,6 +150,8 @@ func executeModifyVolumeRequest(c cloud.Cloud) func(string, modifyVolumeRequest) if err != nil { if errors.Is(err, cloud.ErrInvalidArgument) { return 0, status.Errorf(codes.InvalidArgument, "Could not modify volume (invalid argument) %q: %v", volumeID, err) + } else if errors.Is(err, cloud.ErrNotFound) { + return 0, status.Errorf(codes.NotFound, "Could not modify volume (not found) %q: %v", volumeID, err) } return 0, status.Errorf(codes.Internal, "Could not modify volume %q: %v", volumeID, err) } else { diff --git a/pkg/driver/node.go b/pkg/driver/node.go index 0d03a74cd..ef7ae326d 100644 --- a/pkg/driver/node.go +++ b/pkg/driver/node.go @@ -207,7 +207,7 @@ func (d *NodeService) NodeStageVolume(ctx context.Context, req *csi.NodeStageVol source, err := d.mounter.FindDevicePath(devicePath, volumeID, partition, d.metadata.GetRegion()) if err != nil { - return nil, status.Errorf(codes.Internal, "Failed to find device path %s. %v", devicePath, err) + return nil, status.Errorf(codes.NotFound, "Failed to find device path %s. %v", devicePath, err) } klog.V(4).InfoS("NodeStageVolume: find device path", "devicePath", devicePath, "source", source) @@ -387,7 +387,6 @@ func (d *NodeService) NodeExpandVolume(ctx context.Context, req *csi.NodeExpandV return &csi.NodeExpandVolumeResponse{CapacityBytes: bcap}, nil } } - deviceName, _, err := d.mounter.GetDeviceNameFromMount(volumePath) if err != nil { return nil, status.Errorf(codes.Internal, "failed to get device name from mount %s: %v", volumePath, err) @@ -395,7 +394,7 @@ func (d *NodeService) NodeExpandVolume(ctx context.Context, req *csi.NodeExpandV devicePath, err := d.mounter.FindDevicePath(deviceName, volumeID, "", d.metadata.GetRegion()) if err != nil { - return nil, status.Errorf(codes.Internal, "failed to find device path for device name %s for mount %s: %v", deviceName, req.GetVolumePath(), err) + return nil, status.Errorf(codes.NotFound, "failed to find device path for device name %s for mount %s: %v", deviceName, req.GetVolumePath(), err) } // TODO: lock per volume ID to have some idempotency @@ -626,7 +625,7 @@ func (d *NodeService) nodePublishVolumeForBlock(req *csi.NodePublishVolumeReques source, err := d.mounter.FindDevicePath(devicePath, volumeID, partition, d.metadata.GetRegion()) if err != nil { - return status.Errorf(codes.Internal, "Failed to find device path %s. %v", devicePath, err) + return status.Errorf(codes.NotFound, "Failed to find device path %s. %v", devicePath, err) } klog.V(4).InfoS("NodePublishVolume [block]: find device path", "devicePath", devicePath, "source", source) diff --git a/pkg/driver/node_test.go b/pkg/driver/node_test.go index 59f6ebab2..3d15923bb 100644 --- a/pkg/driver/node_test.go +++ b/pkg/driver/node_test.go @@ -642,7 +642,7 @@ func TestNodeStageVolume(t *testing.T) { m.EXPECT().GetRegion().Return("us-west-2") return m }, - expectedErr: status.Errorf(codes.Internal, "Failed to find device path %s. %v", "/dev/xvdba", errors.New("find device path error")), + expectedErr: status.Errorf(codes.NotFound, "Failed to find device path %s. %v", "/dev/xvdba", errors.New("find device path error")), }, { name: "path_exists_error", @@ -1743,7 +1743,7 @@ func TestNodePublishVolume(t *testing.T) { m.EXPECT().GetRegion().Return("us-west-2") return m }, - expectedErr: status.Error(codes.Internal, "Failed to find device path /dev/xvdba. device path error"), + expectedErr: status.Error(codes.NotFound, "Failed to find device path /dev/xvdba. device path error"), }, } for _, tc := range testCases { @@ -2271,7 +2271,7 @@ func TestNodeExpandVolume(t *testing.T) { return m }, expectedResp: nil, - expectedErr: status.Error(codes.Internal, "failed to find device path for device name device-name for mount /volume/path: failed to find device path"), + expectedErr: status.Error(codes.NotFound, "failed to find device path for device name device-name for mount /volume/path: failed to find device path"), }, { name: "resize_error", diff --git a/tests/sanity/fake_sanity_cloud.go b/tests/sanity/fake_sanity_cloud.go new file mode 100644 index 000000000..cebe5050e --- /dev/null +++ b/tests/sanity/fake_sanity_cloud.go @@ -0,0 +1,219 @@ +// Copyright 2024 The Kubernetes Authors. +// +// Licensed under the Apache License, Version 2.0 (the 'License'); +// you may not use this file except in compliance with the License. +// You may obtain a copy of the License at +// +// http://www.apache.org/licenses/LICENSE-2.0 +// +// Unless required by applicable law or agreed to in writing, software +// distributed under the License is distributed on an 'AS IS' BASIS, +// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. +// See the License for the specific language governing permissions and +// limitations under the License. + +package sanity + +import ( + "context" + "fmt" + "math/rand" + "strconv" + "time" + + "github.com/aws/aws-sdk-go-v2/service/ec2" + "github.com/aws/aws-sdk-go-v2/service/ec2/types" + "github.com/kubernetes-sigs/aws-ebs-csi-driver/pkg/cloud" + "github.com/kubernetes-sigs/aws-ebs-csi-driver/pkg/cloud/metadata" + "github.com/kubernetes-sigs/aws-ebs-csi-driver/pkg/util" +) + +type fakeCloud struct { + fakeMetadata metadata.Metadata + mountPath string + disks map[string]*cloud.Disk + snapshots map[string]*cloud.Snapshot + snapshotNameToID map[string]string +} + +func NewFakeCloud(fmd metadata.Metadata, mp string) *fakeCloud { + return &fakeCloud{ + fakeMetadata: fmd, + mountPath: mp, + disks: make(map[string]*cloud.Disk), + snapshots: make(map[string]*cloud.Snapshot), + snapshotNameToID: make(map[string]string), + } +} + +func (d *fakeCloud) CreateDisk(ctx context.Context, volumeID string, diskOptions *cloud.DiskOptions) (*cloud.Disk, error) { + for _, existingDisk := range d.disks { + if existingDisk.VolumeID == volumeID && existingDisk.CapacityGiB != util.BytesToGiB(diskOptions.CapacityBytes) { + return nil, cloud.ErrAlreadyExists + } + } + + if diskOptions.SnapshotID != "" { + if _, exists := d.snapshots[diskOptions.SnapshotID]; !exists { + return nil, cloud.ErrNotFound + } + newDisk := &cloud.Disk{ + SnapshotID: diskOptions.SnapshotID, + VolumeID: volumeID, + AvailabilityZone: diskOptions.AvailabilityZone, + CapacityGiB: util.BytesToGiB(diskOptions.CapacityBytes), + } + d.disks[volumeID] = newDisk + return newDisk, nil + } + + newDisk := &cloud.Disk{ + VolumeID: volumeID, + AvailabilityZone: diskOptions.AvailabilityZone, + CapacityGiB: util.BytesToGiB(diskOptions.CapacityBytes), + } + d.disks[volumeID] = newDisk + return newDisk, nil +} +func (d *fakeCloud) DeleteDisk(ctx context.Context, volumeID string) (bool, error) { + _, exists := d.disks[volumeID] + if !exists { + return false, cloud.ErrNotFound + } + delete(d.disks, volumeID) + return true, nil +} + +func (d *fakeCloud) GetDiskByID(ctx context.Context, volumeID string) (*cloud.Disk, error) { + disk, exists := d.disks[volumeID] + if !exists { + return nil, cloud.ErrNotFound + } + return disk, nil +} + +func (d *fakeCloud) CreateSnapshot(ctx context.Context, volumeID string, opts *cloud.SnapshotOptions) (*cloud.Snapshot, error) { + snapshotID := fmt.Sprintf("snapshot-%d", rand.New(rand.NewSource(time.Now().UnixNano())).Uint64()) + + _, exists := d.snapshots[snapshotID] + if exists { + return nil, cloud.ErrAlreadyExists + } + newSnapshot := &cloud.Snapshot{ + SnapshotID: snapshotID, + SourceVolumeID: volumeID, + CreationTime: time.Now(), + ReadyToUse: true, + } + d.snapshots[snapshotID] = newSnapshot + d.snapshotNameToID[opts.Tags["CSIVolumeSnapshotName"]] = snapshotID + return newSnapshot, nil +} + +func (d *fakeCloud) DeleteSnapshot(ctx context.Context, snapshotID string) (bool, error) { + if _, exists := d.snapshots[snapshotID]; !exists { + return false, cloud.ErrNotFound + } + for name, id := range d.snapshotNameToID { + if id == snapshotID { + delete(d.snapshotNameToID, name) + break + } + } + delete(d.snapshots, snapshotID) + return true, nil +} +func (d *fakeCloud) GetSnapshotByID(ctx context.Context, snapshotID string) (*cloud.Snapshot, error) { + snapshot, exists := d.snapshots[snapshotID] + if !exists { + return nil, cloud.ErrNotFound + } + return snapshot, nil +} + +func (d *fakeCloud) GetSnapshotByName(ctx context.Context, name string) (*cloud.Snapshot, error) { + if snapshotID, exists := d.snapshotNameToID[name]; exists { + return d.snapshots[snapshotID], nil + } + return nil, cloud.ErrNotFound +} + +func (d *fakeCloud) ListSnapshots(ctx context.Context, sourceVolumeID string, maxResults int32, nextToken string) (*cloud.ListSnapshotsResponse, error) { + var s []*cloud.Snapshot + startIndex := 0 + var err error + + if nextToken != "" { + startIndex, err = strconv.Atoi(nextToken) + if err != nil { + return nil, fmt.Errorf("invalid next token %s", nextToken) + } + } + var nextTokenStr string + count := 0 + for _, snap := range d.snapshots { + if snap.SourceVolumeID == sourceVolumeID || sourceVolumeID == "" { + if startIndex <= count { + s = append(s, snap) + if maxResults > 0 && int32(len(s)) >= maxResults { + nextTokenStr = strconv.Itoa(startIndex + int(maxResults)) + break + } + } + count++ + } + } + + return &cloud.ListSnapshotsResponse{ + Snapshots: s, + NextToken: nextTokenStr, + }, nil +} + +func (d *fakeCloud) AttachDisk(ctx context.Context, volumeID string, instanceID string) (string, error) { + _, diskExists := d.disks[volumeID] + if !diskExists || instanceID != d.fakeMetadata.InstanceID { + return "", cloud.ErrNotFound + } + return d.mountPath, nil +} + +func (d *fakeCloud) DetachDisk(ctx context.Context, volumeID string, instanceID string) error { + _, diskExists := d.disks[volumeID] + if !diskExists || instanceID != d.fakeMetadata.InstanceID { + return cloud.ErrNotFound + } + return nil +} + +func (d *fakeCloud) ResizeOrModifyDisk(ctx context.Context, volumeID string, newSizeBytes int64, modifyOptions *cloud.ModifyDiskOptions) (int32, error) { + disk, exists := d.disks[volumeID] + if !exists { + return 0, cloud.ErrNotFound + } + newSizeGiB := util.BytesToGiB(newSizeBytes) + disk.CapacityGiB = newSizeGiB + d.disks[volumeID] = disk + realSizeGiB := newSizeGiB + return realSizeGiB, nil +} + +func (d *fakeCloud) AvailabilityZones(ctx context.Context) (map[string]struct{}, error) { + return map[string]struct{}{}, nil +} + +func (d *fakeCloud) EnableFastSnapshotRestores(ctx context.Context, availabilityZones []string, snapshotID string) (*ec2.EnableFastSnapshotRestoresOutput, error) { + return &ec2.EnableFastSnapshotRestoresOutput{}, nil +} + +func (d *fakeCloud) GetDiskByName(ctx context.Context, name string, capacityBytes int64) (*cloud.Disk, error) { + return &cloud.Disk{}, nil +} + +func (d *fakeCloud) ModifyTags(ctx context.Context, volumeID string, tagOptions cloud.ModifyTagsOptions) error { + return nil +} + +func (d *fakeCloud) WaitForAttachmentState(ctx context.Context, volumeID, expectedState, expectedInstance, expectedDevice string, alreadyAssigned bool) (*types.VolumeAttachment, error) { + return &types.VolumeAttachment{}, nil +} diff --git a/tests/sanity/fake_sanity_metadata_service.go b/tests/sanity/fake_sanity_metadata_service.go new file mode 100644 index 000000000..4a77c95c1 --- /dev/null +++ b/tests/sanity/fake_sanity_metadata_service.go @@ -0,0 +1,62 @@ +// Copyright 2024 The Kubernetes Authors. +// +// Licensed under the Apache License, Version 2.0 (the 'License'); +// you may not use this file except in compliance with the License. +// You may obtain a copy of the License at +// +// http://www.apache.org/licenses/LICENSE-2.0 +// +// Unless required by applicable law or agreed to in writing, software +// distributed under the License is distributed on an 'AS IS' BASIS, +// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. +// See the License for the specific language governing permissions and +// limitations under the License. + +package sanity + +import ( + "github.com/aws/aws-sdk-go-v2/aws/arn" +) + +type fakeMetadataService struct { + instanceID string + region string + availabilityZone string + outpostArn arn.ARN +} + +func NewFakeMetadataService(id string, r string, az string, oa arn.ARN) *fakeMetadataService { + return &fakeMetadataService{ + instanceID: id, + region: r, + availabilityZone: az, + outpostArn: oa, + } +} +func (m *fakeMetadataService) GetInstanceID() string { + return m.instanceID +} + +func (m *fakeMetadataService) GetInstanceType() string { + return "" +} + +func (m *fakeMetadataService) GetRegion() string { + return m.region +} + +func (m *fakeMetadataService) GetAvailabilityZone() string { + return m.availabilityZone +} + +func (m *fakeMetadataService) GetNumAttachedENIs() int { + return 0 +} + +func (m *fakeMetadataService) GetNumBlockDeviceMappings() int { + return 0 +} + +func (m *fakeMetadataService) GetOutpostArn() arn.ARN { + return m.outpostArn +} diff --git a/tests/sanity/fake_sanity_mounter.go b/tests/sanity/fake_sanity_mounter.go new file mode 100644 index 000000000..36163a399 --- /dev/null +++ b/tests/sanity/fake_sanity_mounter.go @@ -0,0 +1,147 @@ +// Copyright 2024 The Kubernetes Authors. +// +// Licensed under the Apache License, Version 2.0 (the 'License'); +// you may not use this file except in compliance with the License. +// You may obtain a copy of the License at +// +// http://www.apache.org/licenses/LICENSE-2.0 +// +// Unless required by applicable law or agreed to in writing, software +// distributed under the License is distributed on an 'AS IS' BASIS, +// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. +// See the License for the specific language governing permissions and +// limitations under the License. + +package sanity + +import ( + "fmt" + "os" + + "github.com/kubernetes-sigs/aws-ebs-csi-driver/pkg/cloud" + "k8s.io/mount-utils" +) + +type fakeMounter struct { + mounts map[string]string +} + +func NewFakeMounter() *fakeMounter { + return &fakeMounter{ + mounts: make(map[string]string), + } +} + +func (m *fakeMounter) FindDevicePath(devicePath, volumeID, partition, region string) (string, error) { + if len(devicePath) == 0 { + return devicePath, cloud.ErrNotFound + } + return devicePath, nil +} + +func (m *fakeMounter) PreparePublishTarget(target string) error { + if err := m.MakeDir(target); err != nil { + return fmt.Errorf("could not create dir %q: %w", target, err) + } + return nil +} + +func (m *fakeMounter) IsBlockDevice(fullPath string) (bool, error) { + return false, nil +} + +func (m *fakeMounter) GetBlockSizeBytes(devicePath string) (int64, error) { + return 0, nil +} + +func (m *fakeMounter) GetDeviceNameFromMount(mountPath string) (string, int, error) { + return m.mounts[mountPath], 0, nil +} + +func (m *fakeMounter) IsCorruptedMnt(err error) bool { + return false +} + +func (m *fakeMounter) MakeFile(path string) error { + return nil +} + +func (m *fakeMounter) MakeDir(path string) error { + err := os.MkdirAll(path, os.FileMode(0755)) + if err != nil { + if !os.IsExist(err) { + return err + } + } + return nil +} + +func (m *fakeMounter) PathExists(path string) (bool, error) { + _, exists := m.mounts[path] + if !exists { + return false, nil + } + return true, nil +} + +func (m *fakeMounter) Resize(devicePath, deviceMountPath string) (bool, error) { + return false, nil +} + +func (m *fakeMounter) NeedResize(devicePath string, deviceMountPath string) (bool, error) { + return false, nil +} + +func (m *fakeMounter) Unpublish(path string) error { + return m.Unstage(path) +} + +func (m *fakeMounter) Unstage(path string) error { + err := os.RemoveAll(path) + return err +} + +func (m *fakeMounter) Mount(source string, target string, fstype string, options []string) error { + m.mounts[target] = source + return nil +} + +func (m *fakeMounter) CanSafelySkipMountPointCheck() bool { + return false +} + +func (m *fakeMounter) FormatAndMountSensitiveWithFormatOptions(source, target, fstype string, options, sensitiveOptions, formatOptions []string) error { + return nil +} + +func (m *fakeMounter) GetMountRefs(pathname string) ([]string, error) { + return nil, nil +} + +func (m *fakeMounter) IsLikelyNotMountPoint(file string) (bool, error) { + return true, nil +} + +func (m *fakeMounter) IsMountPoint(file string) (bool, error) { + return false, nil +} + +func (m *fakeMounter) List() ([]mount.MountPoint, error) { + return nil, nil +} + +func (m *fakeMounter) MountSensitive(source, target, fstype string, options, sensitiveOptions []string) error { + return nil +} + +func (m *fakeMounter) MountSensitiveWithoutSystemd(source, target, fstype string, options, sensitiveOptions []string) error { + return nil +} + +func (m *fakeMounter) MountSensitiveWithoutSystemdWithMountFlags(source, target, fstype string, options, sensitiveOptions, mountFlags []string) error { + return nil +} + +func (m *fakeMounter) Unmount(target string) error { + return nil +} diff --git a/tests/sanity/sanity_test.go b/tests/sanity/sanity_test.go new file mode 100644 index 000000000..1f998922a --- /dev/null +++ b/tests/sanity/sanity_test.go @@ -0,0 +1,121 @@ +// Copyright 2024 The Kubernetes Authors. +// +// Licensed under the Apache License, Version 2.0 (the 'License'); +// you may not use this file except in compliance with the License. +// You may obtain a copy of the License at +// +// http://www.apache.org/licenses/LICENSE-2.0 +// +// Unless required by applicable law or agreed to in writing, software +// distributed under the License is distributed on an 'AS IS' BASIS, +// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. +// See the License for the specific language governing permissions and +// limitations under the License. + +//go:build linux +// +build linux + +package sanity + +import ( + "fmt" + "os" + "path" + "testing" + + "github.com/aws/aws-sdk-go-v2/aws/arn" + "github.com/golang/mock/gomock" + csisanity "github.com/kubernetes-csi/csi-test/v5/pkg/sanity" + "github.com/kubernetes-sigs/aws-ebs-csi-driver/pkg/cloud/metadata" + d "github.com/kubernetes-sigs/aws-ebs-csi-driver/pkg/driver" + "github.com/kubernetes-sigs/aws-ebs-csi-driver/pkg/util" + "google.golang.org/grpc" + "google.golang.org/grpc/credentials/insecure" +) + +const ( + instanceID = "i-1234567890abcdef0" + region = "us-west-2" + availabilityZone = "us-west-2a" +) + +var ( + fakeMetadata = &metadata.Metadata{ + InstanceID: instanceID, + Region: region, + } + outpostArn = &arn.ARN{ + Partition: "aws", + Service: "outposts", + Region: "us-west-2", + AccountID: "123456789012", + Resource: "op-1234567890abcdef0", + } +) + +func TestSanity(t *testing.T) { + defer func() { + if r := recover(); r != nil { + t.Errorf("Test panicked: %v", r) + } + }() + + mockCtrl := gomock.NewController(t) + defer mockCtrl.Finish() + + tmpDir, err := os.MkdirTemp("", "csi-sanity-") + if err != nil { + t.Fatalf("Failed to create sanity temp working dir: %v", err) + } + defer os.RemoveAll(tmpDir) + + defer func() { + if err = os.RemoveAll(tmpDir); err != nil { + t.Fatalf("Failed to clean up sanity temp working dir %s: %v", tmpDir, err.Error()) + } + }() + + endpoint := fmt.Sprintf("unix:%s/csi.sock", tmpDir) + mountPath := path.Join(tmpDir, "mount") + stagePath := path.Join(tmpDir, "stage") + + fakeMounter, fakeCloud, fakeMetadataService, fakeKubernetesClient := createMockObjects(mockCtrl, mountPath) + + driverOptions := &d.Options{ + Mode: d.AllMode, + ModifyVolumeRequestHandlerTimeout: 60, + Endpoint: endpoint, + } + + drv, err := d.NewDriver(fakeCloud, driverOptions, fakeMounter, fakeMetadataService, fakeKubernetesClient) + if err != nil { + t.Fatalf("Failed to create fake driver: %v", err.Error()) + } + go func() { + if err := drv.Run(); err != nil { + panic(fmt.Sprintf("%v", err)) + } + }() + + config := csisanity.TestConfig{ + TargetPath: mountPath, + StagingPath: stagePath, + Address: endpoint, + DialOptions: []grpc.DialOption{grpc.WithTransportCredentials(insecure.NewCredentials())}, + IDGen: csisanity.DefaultIDGenerator{}, + TestVolumeSize: 10 * util.GiB, + TestVolumeAccessType: "mount", + TestVolumeMutableParameters: map[string]string{"iops": "3014", "throughput": "153"}, + TestVolumeParameters: map[string]string{"type": "gp3", "iops": "3000"}, + } + csisanity.Test(t, config) +} + +func createMockObjects(mockCtrl *gomock.Controller, mountPath string) (*fakeMounter, *fakeCloud, *fakeMetadataService, *d.MockKubernetesClient) { + fakeMounter := NewFakeMounter() + fakeCloud := NewFakeCloud(*fakeMetadata, mountPath) + fakeKubernetesClient := d.NewMockKubernetesClient(mockCtrl) + fakeMetadataService := NewFakeMetadataService(instanceID, region, availabilityZone, *outpostArn) + + return fakeMounter, fakeCloud, fakeMetadataService, fakeKubernetesClient +}