Skip to content

Commit

Permalink
Merge pull request #2994 from redpanda-data/mihaitodor-fix-integratio…
Browse files Browse the repository at this point in the history
…n-tests

Fix integration tests
  • Loading branch information
mihaitodor authored Nov 11, 2024
2 parents f30000d + 88d313c commit 12b50ad
Show file tree
Hide file tree
Showing 17 changed files with 65 additions and 67 deletions.
4 changes: 2 additions & 2 deletions internal/impl/aws/integration_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -47,7 +47,7 @@ func getLocalStack(t testing.TB) (port string) {
ExposedPorts: []string{port + "/tcp"},
PortBindings: map[docker.Port][]docker.PortBinding{
docker.Port(port + "/tcp"): {
docker.PortBinding{HostIP: "", HostPort: port},
docker.PortBinding{HostIP: "", HostPort: port + "/tcp"},
},
},
Env: []string{
Expand All @@ -72,7 +72,7 @@ func getLocalStack(t testing.TB) (port string) {
return
}

func TestIntegration(t *testing.T) {
func TestIntegrationAWS(t *testing.T) {
integration.CheckSkip(t)
t.Parallel()

Expand Down
2 changes: 1 addition & 1 deletion internal/impl/cockroachdb/exploration_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -46,7 +46,7 @@ func TestIntegrationExploration(t *testing.T) {
Repository: "cockroachdb/cockroach",
Tag: "latest",
Cmd: []string{"start-single-node", "--insecure"},
ExposedPorts: []string{"8080", "26257"},
ExposedPorts: []string{"8080/tcp", "26257/tcp"},
})
require.NoError(t, err)
t.Cleanup(func() {
Expand Down
2 changes: 1 addition & 1 deletion internal/impl/cockroachdb/integration_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -46,7 +46,7 @@ func TestIntegrationCRDB(t *testing.T) {
Repository: "cockroachdb/cockroach",
Tag: "latest",
Cmd: []string{"start-single-node", "--insecure"},
ExposedPorts: []string{"8080", "26257"},
ExposedPorts: []string{"8080/tcp", "26257/tcp"},
})
require.NoError(t, err)
t.Cleanup(func() {
Expand Down
2 changes: 1 addition & 1 deletion internal/impl/cypher/output_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -48,7 +48,7 @@ func makeBatch(args ...string) service.MessageBatch {
return batch
}

func TestIntegration(t *testing.T) {
func TestIntegrationCypher(t *testing.T) {
integration.CheckSkip(t)
t.Parallel()

Expand Down
1 change: 1 addition & 0 deletions internal/impl/elasticsearch/aws/integration_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -53,6 +53,7 @@ var elasticIndex = `{
}`

func TestIntegrationElasticsearchAWS(t *testing.T) {
// TODO: Fix this test after migrating to the new Elasticsearch client libs.
t.Skip("Struggling to get localstack es to work, maybe one day")

integration.CheckSkip(t)
Expand Down
13 changes: 7 additions & 6 deletions internal/impl/hdfs/integration_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -24,12 +24,13 @@ import (
"github.com/stretchr/testify/assert"
"github.com/stretchr/testify/require"

_ "github.com/redpanda-data/benthos/v4/public/components/pure"
"github.com/redpanda-data/benthos/v4/public/service/integration"
)

func TestIntegrationHDFS(t *testing.T) {
integration.CheckSkip(t)
// t.Skip() // Skip until we fix the static port bindings

t.Parallel()

pool, err := dockertest.NewPool("")
Expand All @@ -41,12 +42,12 @@ func TestIntegrationHDFS(t *testing.T) {
Repository: "cybermaggedon/hadoop",
Tag: "2.8.2",
Hostname: "localhost",
ExposedPorts: []string{"9000", "50075", "50070", "50010"},
ExposedPorts: []string{"9000/tcp", "50075/tcp", "50070/tcp", "50010/tcp"},
PortBindings: map[docker.Port][]docker.PortBinding{
"9000/tcp": {{HostIP: "", HostPort: "9000"}},
"50070/tcp": {{HostIP: "", HostPort: "50070"}},
"50075/tcp": {{HostIP: "", HostPort: "50075"}},
"50010/tcp": {{HostIP: "", HostPort: "50010"}},
"9000/tcp": {{HostIP: "", HostPort: "9000/tcp"}},
"50070/tcp": {{HostIP: "", HostPort: "50070/tcp"}},
"50075/tcp": {{HostIP: "", HostPort: "50075/tcp"}},
"50010/tcp": {{HostIP: "", HostPort: "50010/tcp"}},
},
}
resource, err := pool.RunWithOptions(options)
Expand Down
6 changes: 3 additions & 3 deletions internal/impl/kafka/enterprise/integration_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -91,7 +91,7 @@ func readNKafkaMessages(ctx context.Context, t testing.TB, address, topic string
return
}

func TestIntegration(t *testing.T) {
func TestKafkaEnterpriseIntegration(t *testing.T) {
integration.CheckSkip(t)
t.Parallel()

Expand All @@ -106,9 +106,9 @@ func TestIntegration(t *testing.T) {
Repository: "redpandadata/redpanda",
Tag: "latest",
Hostname: "redpanda",
ExposedPorts: []string{"9092"},
ExposedPorts: []string{"9092/tcp"},
PortBindings: map[docker.Port][]docker.PortBinding{
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr}},
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr + "/tcp"}},
},
Cmd: []string{
"redpanda",
Expand Down
16 changes: 8 additions & 8 deletions internal/impl/kafka/integration_franz_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -47,9 +47,9 @@ func TestIntegrationFranz(t *testing.T) {
Repository: "redpandadata/redpanda",
Tag: "latest",
Hostname: "redpanda",
ExposedPorts: []string{"9092"},
ExposedPorts: []string{"9092/tcp"},
PortBindings: map[docker.Port][]docker.PortBinding{
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr}},
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr + "/tcp"}},
},
Cmd: []string{
"redpanda",
Expand Down Expand Up @@ -216,9 +216,9 @@ func TestIntegrationFranzSasl(t *testing.T) {
Repository: "redpandadata/redpanda",
Tag: "latest",
Hostname: "redpanda",
ExposedPorts: []string{"9092"},
ExposedPorts: []string{"9092/tcp"},
PortBindings: map[docker.Port][]docker.PortBinding{
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr}},
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr + "/tcp"}},
},
Cmd: []string{
"redpanda",
Expand Down Expand Up @@ -327,9 +327,9 @@ func TestIntegrationFranzOutputFixedTimestamp(t *testing.T) {
Repository: "redpandadata/redpanda",
Tag: "latest",
Hostname: "redpanda",
ExposedPorts: []string{"9092"},
ExposedPorts: []string{"9092/tcp"},
PortBindings: map[docker.Port][]docker.PortBinding{
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr}},
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr + "/tcp"}},
},
Cmd: []string{
"redpanda",
Expand Down Expand Up @@ -399,9 +399,9 @@ func BenchmarkIntegrationFranz(b *testing.B) {
Repository: "redpandadata/redpanda",
Tag: "latest",
Hostname: "redpanda",
ExposedPorts: []string{"9092"},
ExposedPorts: []string{"9092/tcp"},
PortBindings: map[docker.Port][]docker.PortBinding{
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr}},
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr + "/tcp"}},
},
Cmd: []string{
"redpanda",
Expand Down
20 changes: 8 additions & 12 deletions internal/impl/kafka/integration_sarama_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,6 @@ package kafka_test
import (
"context"
"fmt"
"runtime"
"strconv"
"sync"
"testing"
Expand Down Expand Up @@ -54,9 +53,9 @@ func TestIntegrationSaramaCheckpointOneLockUp(t *testing.T) {
Repository: "redpandadata/redpanda",
Tag: "latest",
Hostname: "redpanda",
ExposedPorts: []string{"9092"},
ExposedPorts: []string{"9092/tcp"},
PortBindings: map[docker.Port][]docker.PortBinding{
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr}},
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr + "/tcp"}},
},
Cmd: []string{
"redpanda",
Expand Down Expand Up @@ -217,9 +216,9 @@ func TestIntegrationSaramaRedpanda(t *testing.T) {
Repository: "redpandadata/redpanda",
Tag: "latest",
Hostname: "redpanda",
ExposedPorts: []string{"9092"},
ExposedPorts: []string{"9092/tcp"},
PortBindings: map[docker.Port][]docker.PortBinding{
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr}},
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr + "/tcp"}},
},
Cmd: []string{
"redpanda",
Expand Down Expand Up @@ -453,9 +452,6 @@ input:

func TestIntegrationSaramaOld(t *testing.T) {
integration.CheckSkip(t)
if runtime.GOOS == "darwin" {
t.Skip("skipping test on macos")
}

t.Parallel()

Expand All @@ -472,9 +468,9 @@ func TestIntegrationSaramaOld(t *testing.T) {
kafkaResource, err := pool.RunWithOptions(&dockertest.RunOptions{
Repository: "bitnami/kafka",
Tag: "latest",
ExposedPorts: []string{"9092"},
ExposedPorts: []string{"9092/tcp"},
PortBindings: map[docker.Port][]docker.PortBinding{
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr}},
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr + "/tcp"}},
},
Env: []string{
"KAFKA_CFG_NODE_ID=0",
Expand Down Expand Up @@ -683,9 +679,9 @@ func TestIntegrationSaramaOutputFixedTimestamp(t *testing.T) {
Repository: "redpandadata/redpanda",
Tag: "latest",
Hostname: "redpanda",
ExposedPorts: []string{"9092"},
ExposedPorts: []string{"9092/tcp"},
PortBindings: map[docker.Port][]docker.PortBinding{
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr}},
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr + "/tcp"}},
},
Cmd: []string{
"redpanda",
Expand Down
16 changes: 8 additions & 8 deletions internal/impl/kafka/integration_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -115,9 +115,9 @@ func TestIntegrationRedpanda(t *testing.T) {
Repository: "redpandadata/redpanda",
Tag: "latest",
Hostname: "redpanda",
ExposedPorts: []string{"9092"},
ExposedPorts: []string{"9092/tcp"},
PortBindings: map[docker.Port][]docker.PortBinding{
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr}},
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr + "/tcp"}},
},
Cmd: []string{
"redpanda",
Expand Down Expand Up @@ -268,9 +268,9 @@ func TestIntegrationRedpandaSasl(t *testing.T) {
Repository: "redpandadata/redpanda",
Tag: "latest",
Hostname: "redpanda",
ExposedPorts: []string{"9092"},
ExposedPorts: []string{"9092/tcp"},
PortBindings: map[docker.Port][]docker.PortBinding{
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr}},
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr + "/tcp"}},
},
Cmd: []string{
"redpanda",
Expand Down Expand Up @@ -376,9 +376,9 @@ func TestIntegrationRedpandaOutputFixedTimestamp(t *testing.T) {
Repository: "redpandadata/redpanda",
Tag: "latest",
Hostname: "redpanda",
ExposedPorts: []string{"9092"},
ExposedPorts: []string{"9092/tcp"},
PortBindings: map[docker.Port][]docker.PortBinding{
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr}},
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr + "/tcp"}},
},
Cmd: []string{
"redpanda",
Expand Down Expand Up @@ -448,9 +448,9 @@ func BenchmarkIntegrationRedpanda(b *testing.B) {
Repository: "redpandadata/redpanda",
Tag: "latest",
Hostname: "redpanda",
ExposedPorts: []string{"9092"},
ExposedPorts: []string{"9092/tcp"},
PortBindings: map[docker.Port][]docker.PortBinding{
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr}},
"9092/tcp": {{HostIP: "", HostPort: kafkaPortStr + "/tcp"}},
},
Cmd: []string{
"redpanda",
Expand Down
2 changes: 1 addition & 1 deletion internal/impl/mongodb/input_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -71,7 +71,7 @@ func TestInputIntegration(t *testing.T) {
"MONGO_INITDB_ROOT_USERNAME=mongoadmin",
"MONGO_INITDB_ROOT_PASSWORD=secret",
},
ExposedPorts: []string{"27017"},
ExposedPorts: []string{"27017/tcp"},
})
require.NoError(t, err)

Expand Down
2 changes: 1 addition & 1 deletion internal/impl/mongodb/integration_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -52,7 +52,7 @@ func TestIntegrationMongoDB(t *testing.T) {
"MONGO_INITDB_ROOT_USERNAME=mongoadmin",
"MONGO_INITDB_ROOT_PASSWORD=secret",
},
ExposedPorts: []string{"27017"},
ExposedPorts: []string{"27017/tcp"},
})
require.NoError(t, err)

Expand Down
2 changes: 1 addition & 1 deletion internal/impl/mongodb/processor_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -49,7 +49,7 @@ func TestProcessorIntegration(t *testing.T) {
"MONGO_INITDB_ROOT_USERNAME=mongoadmin",
"MONGO_INITDB_ROOT_PASSWORD=secret",
},
ExposedPorts: []string{"27017"},
ExposedPorts: []string{"27017/tcp"},
})
require.NoError(t, err)

Expand Down
2 changes: 1 addition & 1 deletion internal/impl/nsq/integration_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -22,7 +22,7 @@ import (
"github.com/redpanda-data/benthos/v4/public/service/integration"
)

func TestIntegration(t *testing.T) {
func TestIntegrationNSQ(t *testing.T) {
t.Parallel()

{
Expand Down
6 changes: 3 additions & 3 deletions internal/impl/opensearch/integration_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -50,7 +50,7 @@ func outputFromConf(t testing.TB, confStr string, args ...any) *opensearch.Outpu
return o
}

func TestIntegration(t *testing.T) {
func TestIntegrationOpensearch(t *testing.T) {
integration.CheckSkip(t)
t.Parallel()

Expand Down Expand Up @@ -131,7 +131,7 @@ func TestIntegration(t *testing.T) {
})

t.Run("TestOpenSearchErrorHandling", func(te *testing.T) {
testOpenSearchErrorHandling(urls, client, te)
testOpenSearchErrorHandling(urls, te)
})

t.Run("TestOpenSearchConnect", func(te *testing.T) {
Expand Down Expand Up @@ -252,7 +252,7 @@ action: index
}
}

func testOpenSearchErrorHandling(urls []string, client *os.Client, t *testing.T) {
func testOpenSearchErrorHandling(urls []string, t *testing.T) {
ctx, done := context.WithTimeout(context.Background(), time.Second*30)
defer done()

Expand Down
2 changes: 1 addition & 1 deletion internal/impl/sftp/integration_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -35,7 +35,7 @@ var (
sftpPassword = "pass"
)

func TestIntegration(t *testing.T) {
func TestIntegrationSFTP(t *testing.T) {
integration.CheckSkip(t)
t.Parallel()

Expand Down
34 changes: 17 additions & 17 deletions internal/impl/spicedb/watch_input_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -28,7 +28,7 @@ import (
"google.golang.org/protobuf/encoding/protojson"
)

func TestIntegration(t *testing.T) {
func TestIntegrationSpiceDB(t *testing.T) {
integration.CheckSkip(t)
t.Parallel()
ctx := context.Background()
Expand Down Expand Up @@ -67,22 +67,22 @@ cache: test_cache
err = pool.Retry(func() error {
r, err := client.WriteSchema(ctx, &v1.WriteSchemaRequest{
Schema: `
definition user {}
definition document {
relation writer: user
relation reader: user
/**
* edit determines whether a user can edit the document
*/
permission edit = writer
/**
* view determines whether a user can view the document
*/
permission view = reader + writer
}`,
definition user {}
definition document {
relation writer: user
relation reader: user
/**
* edit determines whether a user can edit the document
*/
permission edit = writer
/**
* view determines whether a user can view the document
*/
permission view = reader + writer
}`,
})
if err != nil {
return err
Expand Down

0 comments on commit 12b50ad

Please sign in to comment.