Skip to content

Add runners/prism/java to java PreCommit (#32507) #7277

Add runners/prism/java to java PreCommit (#32507)

Add runners/prism/java to java PreCommit (#32507) #7277

GitHub Actions / Test Results failed Sep 20, 2024 in 0s

1 parse errors, 77 pass in 1m 1s

77 tests   77 ✅  1m 1s ⏱️
 7 suites   0 💤
 8 files     0 ❌
 1 errors

Results for commit 7581eb1.

Annotations

Check failure on line 0 in sdks/java/io/jdbc/build/test-results/integrationTest/TEST-org.apache.beam.sdk.io.jdbc.JdbcIOAutoPartitioningIT.xml

See this annotation in the file changed.

@github-actions github-actions / Test Results

Error processing result file

CData section too big found, line 51061, column 222 (TEST-org.apache.beam.sdk.io.jdbc.JdbcIOAutoPartitioningIT.xml, line 51061)
Raw output
sdks/java/io/jdbc/build/test-results/integrationTest/TEST-org.apache.beam.sdk.io.jdbc.JdbcIOAutoPartitioningIT.xml

Check notice on line 0 in .github

See this annotation in the file changed.

@github-actions github-actions / Test Results

77 tests found

There are 77 tests, see "Raw output" for the full list of tests.
Raw output
org.apache.beam.sdk.io.jdbc.JdbcIOExceptionHandlingParameterizedTest ‑ testExceptionsAndRetries[0]
org.apache.beam.sdk.io.jdbc.JdbcIOExceptionHandlingParameterizedTest ‑ testExceptionsAndRetries[1]
org.apache.beam.sdk.io.jdbc.JdbcIOExceptionHandlingParameterizedTest ‑ testExceptionsAndRetries[2]
org.apache.beam.sdk.io.jdbc.JdbcIOExceptionHandlingParameterizedTest ‑ testExceptionsAndRetries[3]
org.apache.beam.sdk.io.jdbc.JdbcIOExceptionHandlingParameterizedTest ‑ testExceptionsAndRetries[4]
org.apache.beam.sdk.io.jdbc.JdbcIOExceptionHandlingParameterizedTest ‑ testExceptionsAndRetries[5]
org.apache.beam.sdk.io.jdbc.JdbcIOExceptionHandlingParameterizedTest ‑ testExceptionsAndRetries[6]
org.apache.beam.sdk.io.jdbc.JdbcIOExceptionHandlingParameterizedTest ‑ testExceptionsAndRetries[7]
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testCustomFluentBackOffConfiguration
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testDataSourceConfigurationDataSourceWithPool
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testDataSourceConfigurationDataSourceWithoutPool
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testDataSourceConfigurationDriverAndUrl
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testDataSourceConfigurationNullPassword
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testDataSourceConfigurationNullUsernameAndPassword
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testDataSourceConfigurationUsernameAndPassword
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testDefaultRetryStrategy
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testGetPreparedStatementSetCaller
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testGetPreparedStatementSetCallerForArray
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testGetPreparedStatementSetCallerForLogicalTypes
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testGetPreparedStatementSetNullsCaller
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testIfNumPartitionsIsZero
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testLowerBoundIsMoreThanUpperBound
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testPartitioningDateTime
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testPartitioningLongs
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testPartitioningStringsWithCustomPartitionsHelper
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testRead
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testReadRowsFailedToGetSchema
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testReadRowsWithDataSourceConfiguration
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testReadRowsWithNumericFields
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testReadRowsWithNumericFieldsWithExcessPrecision
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testReadRowsWithoutStatementPreparator
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testReadWithCoderInference
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testReadWithPartitions
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testReadWithPartitionsBySubqery
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testReadWithSchema
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testReadWithSingleStringParameter
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testSerializationAndCachingOfPoolingDataSourceProvider
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testSetConnectoinInitSqlFailWithDerbyDB
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testWrite
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testWriteReadNullableTypes
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testWriteRowsResultsAndWaitOn
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testWriteWithAutosharding
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testWriteWithBackoff
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testWriteWithEmptyPCollection
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testWriteWithResultsAndWaitOn
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testWriteWithWriteResults
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testWriteWithoutPreparedStatement
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testWriteWithoutPreparedStatementAndNonRowType
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testWriteWithoutPreparedStatementWithReadRows
org.apache.beam.sdk.io.jdbc.JdbcIOTest ‑ testWriteWithoutPsWithNonNullableTableField
org.apache.beam.sdk.io.jdbc.JdbcReadSchemaTransformProviderTest ‑ testInvalidReadSchemaOptions
org.apache.beam.sdk.io.jdbc.JdbcReadSchemaTransformProviderTest ‑ testRead
org.apache.beam.sdk.io.jdbc.JdbcReadSchemaTransformProviderTest ‑ testReadWithJdbcTypeSpecified
org.apache.beam.sdk.io.jdbc.JdbcReadSchemaTransformProviderTest ‑ testValidReadSchemaOptions
org.apache.beam.sdk.io.jdbc.JdbcSchemaIOProviderTest ‑ testAbleToReadDataSourceConfiguration
org.apache.beam.sdk.io.jdbc.JdbcSchemaIOProviderTest ‑ testPartitionedRead
org.apache.beam.sdk.io.jdbc.JdbcSchemaIOProviderTest ‑ testPartitionedReadThatShouldntWork
org.apache.beam.sdk.io.jdbc.JdbcUtilTest ‑ testDatetimePartitioningWithMultiKey
org.apache.beam.sdk.io.jdbc.JdbcUtilTest ‑ testDatetimePartitioningWithSingleKey
org.apache.beam.sdk.io.jdbc.JdbcUtilTest ‑ testGetPreparedStatementSetCaller
org.apache.beam.sdk.io.jdbc.JdbcUtilTest ‑ testLongPartitioningNotEnoughRanges
org.apache.beam.sdk.io.jdbc.JdbcUtilTest ‑ testLongPartitioningWithSingleKey
org.apache.beam.sdk.io.jdbc.JdbcUtilTest ‑ testSavesFilesAsExpected
org.apache.beam.sdk.io.jdbc.JdbcUtilTest ‑ testStringPartitioningWithMultiletter
org.apache.beam.sdk.io.jdbc.JdbcUtilTest ‑ testStringPartitioningWithSingleKeyFn
org.apache.beam.sdk.io.jdbc.JdbcUtilTest ‑ testStringPartitioningWithSingleKeyMultiletterFn
org.apache.beam.sdk.io.jdbc.JdbcWriteSchemaTransformProviderTest ‑ testInvalidWriteSchemaOptions
org.apache.beam.sdk.io.jdbc.JdbcWriteSchemaTransformProviderTest ‑ testValidWriteSchemaOptions
org.apache.beam.sdk.io.jdbc.JdbcWriteSchemaTransformProviderTest ‑ testWriteToTable
org.apache.beam.sdk.io.jdbc.JdbcWriteSchemaTransformProviderTest ‑ testWriteToTableWithJdbcTypeSpecified
org.apache.beam.sdk.io.jdbc.SchemaUtilTest ‑ testBeamRowMapperArray
org.apache.beam.sdk.io.jdbc.SchemaUtilTest ‑ testBeamRowMapperDateTime
org.apache.beam.sdk.io.jdbc.SchemaUtilTest ‑ testBeamRowMapperPrimitiveTypes
org.apache.beam.sdk.io.jdbc.SchemaUtilTest ‑ testJdbcLogicalTypesMapValidAvroSchemaIT
org.apache.beam.sdk.io.jdbc.SchemaUtilTest ‑ testSchemaFieldComparator
org.apache.beam.sdk.io.jdbc.SchemaUtilTest ‑ testSchemaFieldTypeComparator
org.apache.beam.sdk.io.jdbc.SchemaUtilTest ‑ testToBeamSchema