Skip to content

[Do not merge] Test vendored_grpc_1_60_1:0.3 #33006

[Do not merge] Test vendored_grpc_1_60_1:0.3

[Do not merge] Test vendored_grpc_1_60_1:0.3 #33006

GitHub Actions / Test Results failed Oct 17, 2024 in 0s

1 fail, 346 pass in 2m 6s

347 tests  +228   346 ✅ +227   2m 6s ⏱️ + 1m 28s
 46 suites + 27     0 💤 ±  0 
 46 files   + 27     1 ❌ +  1 

Results for commit 9c47193. ± Comparison against earlier commit e98e301.

Annotations

Check warning on line 0 in org.apache.beam.sdk.io.aws2.sqs.SqsIOWriteBatchesTest

See this annotation in the file changed.

@github-actions github-actions / Test Results

testWriteBatchesWithTimeout (org.apache.beam.sdk.io.aws2.sqs.SqsIOWriteBatchesTest) failed

sdks/java/io/amazon-web-services2/build/test-results/test/TEST-org.apache.beam.sdk.io.aws2.sqs.SqsIOWriteBatchesTest.xml [took 0s]
Raw output
Argument(s) are different! Wanted:
sqs.sendMessageBatch(
    SendMessageBatchRequest(QueueUrl=queue, Entries=[SendMessageBatchRequestEntry(Id=0, MessageBody=0), SendMessageBatchRequestEntry(Id=1, MessageBody=1), SendMessageBatchRequestEntry(Id=2, MessageBody=2)])
);
-> at org.apache.beam.sdk.io.aws2.sqs.SqsIOWriteBatchesTest.testWriteBatchesWithTimeout(SqsIOWriteBatchesTest.java:268)
Actual invocations have different arguments:
sqs.sendMessageBatch(
    SendMessageBatchRequest(QueueUrl=queue, Entries=[SendMessageBatchRequestEntry(Id=0, MessageBody=0), SendMessageBatchRequestEntry(Id=1, MessageBody=1)])
);
-> at org.apache.beam.sdk.io.aws2.sqs.SqsIO$WriteBatches$BatchHandler.sendMessageBatch(SqsIO.java:617)
sqs.sendMessageBatch(
    SendMessageBatchRequest(QueueUrl=queue, Entries=[SendMessageBatchRequestEntry(Id=2, MessageBody=2), SendMessageBatchRequestEntry(Id=3, MessageBody=3), SendMessageBatchRequestEntry(Id=4, MessageBody=4)])
);
-> at org.apache.beam.sdk.io.aws2.sqs.SqsIO$WriteBatches$BatchHandler.sendMessageBatch(SqsIO.java:617)
sqs.close(
    
);
-> at org.apache.beam.sdk.io.aws2.sqs.SqsIO$WriteBatches$BatchHandler.close(SqsIO.java:678)

	at org.apache.beam.sdk.io.aws2.sqs.SqsIOWriteBatchesTest.testWriteBatchesWithTimeout(SqsIOWriteBatchesTest.java:268)
	at sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
	at sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:62)
	at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
	at java.lang.reflect.Method.invoke(Method.java:498)
	at org.junit.runners.model.FrameworkMethod$1.runReflectiveCall(FrameworkMethod.java:59)
	at org.junit.internal.runners.model.ReflectiveCallable.run(ReflectiveCallable.java:12)
	at org.junit.runners.model.FrameworkMethod.invokeExplosively(FrameworkMethod.java:56)
	at org.junit.internal.runners.statements.InvokeMethod.evaluate(InvokeMethod.java:17)
	at org.junit.internal.runners.statements.RunBefores.evaluate(RunBefores.java:26)
	at org.mockito.internal.runners.DefaultInternalRunner$1$1.evaluate(DefaultInternalRunner.java:54)
	at org.junit.rules.ExternalResource$1.evaluate(ExternalResource.java:54)
	at org.apache.beam.sdk.testing.TestPipeline$1.evaluate(TestPipeline.java:331)
	at org.junit.runners.ParentRunner$3.evaluate(ParentRunner.java:306)
	at org.junit.runners.BlockJUnit4ClassRunner$1.evaluate(BlockJUnit4ClassRunner.java:100)
	at org.junit.runners.ParentRunner.runLeaf(ParentRunner.java:366)
	at org.junit.runners.BlockJUnit4ClassRunner.runChild(BlockJUnit4ClassRunner.java:103)
	at org.junit.runners.BlockJUnit4ClassRunner.runChild(BlockJUnit4ClassRunner.java:63)
	at org.junit.runners.ParentRunner$4.run(ParentRunner.java:331)
	at org.junit.runners.ParentRunner$1.schedule(ParentRunner.java:79)
	at org.junit.runners.ParentRunner.runChildren(ParentRunner.java:329)
	at org.junit.runners.ParentRunner.access$100(ParentRunner.java:66)
	at org.junit.runners.ParentRunner$2.evaluate(ParentRunner.java:293)
	at org.junit.runners.ParentRunner$3.evaluate(ParentRunner.java:306)
	at org.junit.runners.ParentRunner.run(ParentRunner.java:413)
	at org.mockito.internal.runners.DefaultInternalRunner$1.run(DefaultInternalRunner.java:99)
	at org.mockito.internal.runners.DefaultInternalRunner.run(DefaultInternalRunner.java:105)
	at org.mockito.internal.runners.StrictRunner.run(StrictRunner.java:40)
	at org.mockito.junit.MockitoJUnitRunner.run(MockitoJUnitRunner.java:163)
	at org.gradle.api.internal.tasks.testing.junit.JUnitTestClassExecutor.runTestClass(JUnitTestClassExecutor.java:112)
	at org.gradle.api.internal.tasks.testing.junit.JUnitTestClassExecutor.execute(JUnitTestClassExecutor.java:58)
	at org.gradle.api.internal.tasks.testing.junit.JUnitTestClassExecutor.execute(JUnitTestClassExecutor.java:40)
	at org.gradle.api.internal.tasks.testing.junit.AbstractJUnitTestClassProcessor.processTestClass(AbstractJUnitTestClassProcessor.java:60)
	at org.gradle.api.internal.tasks.testing.SuiteTestClassProcessor.processTestClass(SuiteTestClassProcessor.java:52)
	at sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
	at sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:62)
	at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
	at java.lang.reflect.Method.invoke(Method.java:498)
	at org.gradle.internal.dispatch.ReflectionDispatch.dispatch(ReflectionDispatch.java:36)
	at org.gradle.internal.dispatch.ReflectionDispatch.dispatch(ReflectionDispatch.java:24)
	at org.gradle.internal.dispatch.ContextClassLoaderDispatch.dispatch(ContextClassLoaderDispatch.java:33)
	at org.gradle.internal.dispatch.ProxyDispatchAdapter$DispatchingInvocationHandler.invoke(ProxyDispatchAdapter.java:94)
	at com.sun.proxy.$Proxy2.processTestClass(Unknown Source)
	at org.gradle.api.internal.tasks.testing.worker.TestWorker$2.run(TestWorker.java:176)
	at org.gradle.api.internal.tasks.testing.worker.TestWorker.executeAndMaintainThreadName(TestWorker.java:129)
	at org.gradle.api.internal.tasks.testing.worker.TestWorker.execute(TestWorker.java:100)
	at org.gradle.api.internal.tasks.testing.worker.TestWorker.execute(TestWorker.java:60)
	at org.gradle.process.internal.worker.child.ActionExecutionWorker.execute(ActionExecutionWorker.java:56)
	at org.gradle.process.internal.worker.child.SystemApplicationClassLoaderWorker.call(SystemApplicationClassLoaderWorker.java:113)
	at org.gradle.process.internal.worker.child.SystemApplicationClassLoaderWorker.call(SystemApplicationClassLoaderWorker.java:65)
	at worker.org.gradle.process.internal.worker.GradleWorkerMain.run(GradleWorkerMain.java:69)
	at worker.org.gradle.process.internal.worker.GradleWorkerMain.main(GradleWorkerMain.java:74)

Check notice on line 0 in .github

See this annotation in the file changed.

@github-actions github-actions / Test Results

347 tests found

There are 347 tests, see "Raw output" for the full list of tests.
Raw output
org.apache.beam.sdk.io.aws2.common.AsyncBatchWriteHandlerTest ‑ correctlyLimitConcurrency
org.apache.beam.sdk.io.aws2.common.AsyncBatchWriteHandlerTest ‑ propagateErrorOnPutRecords
org.apache.beam.sdk.io.aws2.common.AsyncBatchWriteHandlerTest ‑ propagateErrorOnWaitForCompletion
org.apache.beam.sdk.io.aws2.common.AsyncBatchWriteHandlerTest ‑ propagateErrorWhenPolling
org.apache.beam.sdk.io.aws2.common.AsyncBatchWriteHandlerTest ‑ retryLimitOnPartialSuccessById
org.apache.beam.sdk.io.aws2.common.AsyncBatchWriteHandlerTest ‑ retryLimitOnPartialSuccessByPosition
org.apache.beam.sdk.io.aws2.common.AsyncBatchWriteHandlerTest ‑ retryOnPartialSuccessById
org.apache.beam.sdk.io.aws2.common.AsyncBatchWriteHandlerTest ‑ retryOnPartialSuccessByPosition
org.apache.beam.sdk.io.aws2.common.ClientBuilderFactoryTest ‑ testAsyncEmptyHttpConfiguration
org.apache.beam.sdk.io.aws2.common.ClientBuilderFactoryTest ‑ testAsyncHttpConfiguration
org.apache.beam.sdk.io.aws2.common.ClientBuilderFactoryTest ‑ testAsyncHttpSocketConfiguration
org.apache.beam.sdk.io.aws2.common.ClientBuilderFactoryTest ‑ testAsyncProxyConfiguration
org.apache.beam.sdk.io.aws2.common.ClientBuilderFactoryTest ‑ testBaseSettingsFromClientConfig
org.apache.beam.sdk.io.aws2.common.ClientBuilderFactoryTest ‑ testBaseSettingsFromOptions
org.apache.beam.sdk.io.aws2.common.ClientBuilderFactoryTest ‑ testBuildClientFromOptions
org.apache.beam.sdk.io.aws2.common.ClientBuilderFactoryTest ‑ testCheckConfigurationUsingConfig
org.apache.beam.sdk.io.aws2.common.ClientBuilderFactoryTest ‑ testCheckConfigurationUsingOptions
org.apache.beam.sdk.io.aws2.common.ClientBuilderFactoryTest ‑ testEndpointFromClientConfig
org.apache.beam.sdk.io.aws2.common.ClientBuilderFactoryTest ‑ testEndpointFromOptions
org.apache.beam.sdk.io.aws2.common.ClientBuilderFactoryTest ‑ testGetFactoryInstance
org.apache.beam.sdk.io.aws2.common.ClientBuilderFactoryTest ‑ testRetryConfiguration
org.apache.beam.sdk.io.aws2.common.ClientBuilderFactoryTest ‑ testSyncEmptyHttpConfiguration
org.apache.beam.sdk.io.aws2.common.ClientBuilderFactoryTest ‑ testSyncHttpConfiguration
org.apache.beam.sdk.io.aws2.common.ClientBuilderFactoryTest ‑ testSyncProxyConfiguration
org.apache.beam.sdk.io.aws2.common.ClientBuilderFactoryTest ‑ testValidate
org.apache.beam.sdk.io.aws2.common.ClientConfigurationTest ‑ testJavaSerialization
org.apache.beam.sdk.io.aws2.common.ClientConfigurationTest ‑ testJsonSerialization
org.apache.beam.sdk.io.aws2.common.HttpClientConfigurationTest ‑ testJsonSerialization
org.apache.beam.sdk.io.aws2.common.ObjectPoolTest ‑ closeClientsOnceReleased
org.apache.beam.sdk.io.aws2.common.ObjectPoolTest ‑ closeClientsOnceReleasedByKey
org.apache.beam.sdk.io.aws2.common.ObjectPoolTest ‑ concurrentRetainRelease
org.apache.beam.sdk.io.aws2.common.ObjectPoolTest ‑ recreateClientOnceReleased
org.apache.beam.sdk.io.aws2.common.ObjectPoolTest ‑ releaseWithError
org.apache.beam.sdk.io.aws2.common.ObjectPoolTest ‑ shareClientsOfSameConfiguration
org.apache.beam.sdk.io.aws2.common.RetryConfigurationTest ‑ testJsonSerialization
org.apache.beam.sdk.io.aws2.common.RetryConfigurationTest ‑ verifyBaseBackoffLargerZero
org.apache.beam.sdk.io.aws2.common.RetryConfigurationTest ‑ verifyMaxBackoffLargerZero
org.apache.beam.sdk.io.aws2.common.RetryConfigurationTest ‑ verifyNumRetriesNotNegative
org.apache.beam.sdk.io.aws2.common.RetryConfigurationTest ‑ verifyThrottledBaseBackoffLargerZero
org.apache.beam.sdk.io.aws2.dynamodb.AttributeValueCoderTest ‑ shouldPassForBooleanType
org.apache.beam.sdk.io.aws2.dynamodb.AttributeValueCoderTest ‑ shouldPassForByteArray
org.apache.beam.sdk.io.aws2.dynamodb.AttributeValueCoderTest ‑ shouldPassForListOfString
org.apache.beam.sdk.io.aws2.dynamodb.AttributeValueCoderTest ‑ shouldPassForListType
org.apache.beam.sdk.io.aws2.dynamodb.AttributeValueCoderTest ‑ shouldPassForMapType
org.apache.beam.sdk.io.aws2.dynamodb.AttributeValueCoderTest ‑ shouldPassForNullType
org.apache.beam.sdk.io.aws2.dynamodb.AttributeValueCoderTest ‑ shouldPassForNumberType
org.apache.beam.sdk.io.aws2.dynamodb.AttributeValueCoderTest ‑ shouldPassForOneListOfByteArray
org.apache.beam.sdk.io.aws2.dynamodb.AttributeValueCoderTest ‑ shouldPassForOneListOfNumber
org.apache.beam.sdk.io.aws2.dynamodb.AttributeValueCoderTest ‑ shouldPassForStringType
org.apache.beam.sdk.io.aws2.dynamodb.DynamoDBIOReadTest ‑ testReadInvalidTotalSegments
org.apache.beam.sdk.io.aws2.dynamodb.DynamoDBIOReadTest ‑ testReadMissingScanRequestFn
org.apache.beam.sdk.io.aws2.dynamodb.DynamoDBIOReadTest ‑ testReadMissingTotalSegments
org.apache.beam.sdk.io.aws2.dynamodb.DynamoDBIOReadTest ‑ testReadOneSegment
org.apache.beam.sdk.io.aws2.dynamodb.DynamoDBIOReadTest ‑ testReadThreeSegments
org.apache.beam.sdk.io.aws2.dynamodb.DynamoDBIOReadTest ‑ testReadWithCustomLimit
org.apache.beam.sdk.io.aws2.dynamodb.DynamoDBIOReadTest ‑ testReadWithStartKey
org.apache.beam.sdk.io.aws2.dynamodb.DynamoDBIOWriteTest ‑ testWriteDeleteItems
org.apache.beam.sdk.io.aws2.dynamodb.DynamoDBIOWriteTest ‑ testWriteDeleteItemsWithDuplicates
org.apache.beam.sdk.io.aws2.dynamodb.DynamoDBIOWriteTest ‑ testWritePutItems
org.apache.beam.sdk.io.aws2.dynamodb.DynamoDBIOWriteTest ‑ testWritePutItemsWithDuplicates
org.apache.beam.sdk.io.aws2.dynamodb.DynamoDBIOWriteTest ‑ testWritePutItemsWithDuplicatesByKey
org.apache.beam.sdk.io.aws2.dynamodb.DynamoDBIOWriteTest ‑ testWritePutItemsWithPartialSuccess
org.apache.beam.sdk.io.aws2.kinesis.CustomOptionalTest ‑ absentThrowsNoSuchElementExceptionOnGet
org.apache.beam.sdk.io.aws2.kinesis.CustomOptionalTest ‑ testEqualsAndHashCode
org.apache.beam.sdk.io.aws2.kinesis.EFOKinesisReaderTest ‑ getCheckpointMarkReturnsCheckpoints
org.apache.beam.sdk.io.aws2.kinesis.EFOKinesisReaderTest ‑ readsThroughAllDataAvailable
org.apache.beam.sdk.io.aws2.kinesis.EFOKinesisReaderTest ‑ returnsCurrentWatermark
org.apache.beam.sdk.io.aws2.kinesis.EFOKinesisReaderTest ‑ startReturnsFalseIfNoDataAtTheBeginning
org.apache.beam.sdk.io.aws2.kinesis.EFOKinesisReaderTest ‑ startReturnsTrueIfSomeDataAvailable
org.apache.beam.sdk.io.aws2.kinesis.EFOKinesisReaderTest ‑ throwsNoSuchElementExceptionIfNoData
org.apache.beam.sdk.io.aws2.kinesis.EFOShardSubscribersPoolTest ‑ checkpointEqualsToInitStateIfNothingIsConsumed
org.apache.beam.sdk.io.aws2.kinesis.EFOShardSubscribersPoolTest ‑ doesNotIntroduceDuplicatesWithAggregatedRecordsCheckpoints
org.apache.beam.sdk.io.aws2.kinesis.EFOShardSubscribersPoolTest ‑ handlesAggregatedRecords
org.apache.beam.sdk.io.aws2.kinesis.EFOShardSubscribersPoolTest ‑ poolFailsWhenConsumerDoesNotExist
org.apache.beam.sdk.io.aws2.kinesis.EFOShardSubscribersPoolTest ‑ poolFailsWhenNonRecoverableErrorOccurs
org.apache.beam.sdk.io.aws2.kinesis.EFOShardSubscribersPoolTest ‑ poolHandlesShardDown
org.apache.beam.sdk.io.aws2.kinesis.EFOShardSubscribersPoolTest ‑ poolHandlesShardUp
org.apache.beam.sdk.io.aws2.kinesis.EFOShardSubscribersPoolTest ‑ poolHandlesShardUpWithRecords
org.apache.beam.sdk.io.aws2.kinesis.EFOShardSubscribersPoolTest ‑ poolReSubscribesAndReadsManyEvents
org.apache.beam.sdk.io.aws2.kinesis.EFOShardSubscribersPoolTest ‑ poolReSubscribesAndReadsRecords
org.apache.beam.sdk.io.aws2.kinesis.EFOShardSubscribersPoolTest ‑ poolReSubscribesAndReadsRecordsAfterCheckPoint
org.apache.beam.sdk.io.aws2.kinesis.EFOShardSubscribersPoolTest ‑ poolReSubscribesAndReadsRecordsAfterCheckPointWithPositiveSubSeqNumber
org.apache.beam.sdk.io.aws2.kinesis.EFOShardSubscribersPoolTest ‑ poolReSubscribesAndReadsRecordsWithAtTimestamp
org.apache.beam.sdk.io.aws2.kinesis.EFOShardSubscribersPoolTest ‑ poolReSubscribesAndReadsRecordsWithTrimHorizon
org.apache.beam.sdk.io.aws2.kinesis.EFOShardSubscribersPoolTest ‑ poolReSubscribesAndSkipsAllRecordsWithAtTimestampGreaterThanRecords
org.apache.beam.sdk.io.aws2.kinesis.EFOShardSubscribersPoolTest ‑ poolReSubscribesFromInitialWhenRecoverableErrorOccursImmediately
org.apache.beam.sdk.io.aws2.kinesis.EFOShardSubscribersPoolTest ‑ poolReSubscribesWhenManyRecoverableErrorsOccur
org.apache.beam.sdk.io.aws2.kinesis.EFOShardSubscribersPoolTest ‑ poolReSubscribesWhenNoRecordsCome
org.apache.beam.sdk.io.aws2.kinesis.EFOShardSubscribersPoolTest ‑ poolReSubscribesWhenRecoverableErrorOccurs
org.apache.beam.sdk.io.aws2.kinesis.EFOShardSubscribersPoolTest ‑ poolWatermarkReturnsTsOfOldestAcknowledgedRecord
org.apache.beam.sdk.io.aws2.kinesis.EFOShardSubscribersPoolTest ‑ skipsEntireAggregatedBatch
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOOptionsTest ‑ testConsumerMapping
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOOptionsTest ‑ testNullConsumerArn
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOOptionsTest ‑ testSerializeDeserializeDefaults
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOReadTest ‑ testReadDefaults
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOReadTest ‑ testReadFromShards
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOReadTest ‑ testReadWithEFOFromShards
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOReadTest ‑ testReadWithLimitExceeded
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ testShardRangesRefresh
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ testWrite
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ testWriteAggregatedByDefault
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ testWriteAggregatedShardAware
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ testWriteAggregatedShardRefreshDisabled
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ testWriteAggregatedShardRefreshPending
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ testWriteAggregatedUsingExplicitPartitioner
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ testWriteAggregatedWithMaxBufferTime
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ testWriteAggregatedWithMaxBytes
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ testWriteAggregatedWithMaxBytesAndBatchMaxBytes
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ testWriteAggregatedWithMaxBytesAndBatchMaxRecords
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ testWriteAggregatedWithShardsRefresh
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ testWriteFailure
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ testWriteWithBatchMaxBytes
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ testWriteWithBatchMaxRecords
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ testWriteWithPartialSuccess
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ validateBatchMaxBytesTooHigh
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ validateBatchMaxBytesTooLow
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ validateBatchMaxRecordsTooHigh
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ validateBatchMaxRecordsTooLow
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ validateEmptyStreamName
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ validateInvalidConcurrentRequests
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ validateMissingPartitioner
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ validateMissingSerializer
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ validateMissingStreamName
org.apache.beam.sdk.io.aws2.kinesis.KinesisIOWriteTest ‑ validateRecordAggregationMaxBytesAboveLimit
org.apache.beam.sdk.io.aws2.kinesis.KinesisReaderCheckpointTest ‑ isImmutable
org.apache.beam.sdk.io.aws2.kinesis.KinesisReaderCheckpointTest ‑ splitsCheckpointAccordingly
org.apache.beam.sdk.io.aws2.kinesis.KinesisReaderCheckpointTest ‑ testJavaSerialization
org.apache.beam.sdk.io.aws2.kinesis.KinesisReaderTest ‑ getSplitBacklogBytesShouldReturnBacklogUnknown
org.apache.beam.sdk.io.aws2.kinesis.KinesisReaderTest ‑ getSplitBacklogBytesShouldReturnLastSeenValueWhenCalledFrequently
org.apache.beam.sdk.io.aws2.kinesis.KinesisReaderTest ‑ getSplitBacklogBytesShouldReturnLastSeenValueWhenKinesisExceptionsOccur
org.apache.beam.sdk.io.aws2.kinesis.KinesisReaderTest ‑ getSplitBacklogBytesShouldReturnUnknownIfNotStarted
org.apache.beam.sdk.io.aws2.kinesis.KinesisReaderTest ‑ readsThroughAllDataAvailable
org.apache.beam.sdk.io.aws2.kinesis.KinesisReaderTest ‑ returnsCurrentWatermark
org.apache.beam.sdk.io.aws2.kinesis.KinesisReaderTest ‑ startReturnsFalseIfNoDataAtTheBeginning
org.apache.beam.sdk.io.aws2.kinesis.KinesisReaderTest ‑ startReturnsTrueIfSomeDataAvailable
org.apache.beam.sdk.io.aws2.kinesis.KinesisReaderTest ‑ throwsNoSuchElementExceptionIfNoData
org.apache.beam.sdk.io.aws2.kinesis.KinesisRecordCoderTest ‑ encodingAndDecodingWorks
org.apache.beam.sdk.io.aws2.kinesis.KinesisSourceTest ‑ shouldThrowLimitExceededExceptionForShardListing
org.apache.beam.sdk.io.aws2.kinesis.KinesisSourceTest ‑ shouldThrowServiceErrorForShardListing
org.apache.beam.sdk.io.aws2.kinesis.KinesisSourceTest ‑ testConsumerArnForSpecificStreamNotPassedInPipelineOptions
org.apache.beam.sdk.io.aws2.kinesis.KinesisSourceTest ‑ testConsumerArnInPipelineOptionsDiscardsIOSetting
org.apache.beam.sdk.io.aws2.kinesis.KinesisSourceTest ‑ testConsumerArnInPipelineOptionsOverwritesIOSetting
org.apache.beam.sdk.io.aws2.kinesis.KinesisSourceTest ‑ testConsumerArnNotPassed
org.apache.beam.sdk.io.aws2.kinesis.KinesisSourceTest ‑ testConsumerArnPassedInIO
org.apache.beam.sdk.io.aws2.kinesis.KinesisSourceTest ‑ testConsumerArnPassedInPipelineOptions
org.apache.beam.sdk.io.aws2.kinesis.KinesisSourceTest ‑ testCreateReaderOfCorrectType
org.apache.beam.sdk.io.aws2.kinesis.KinesisSourceTest ‑ testSplitGeneratesCorrectNumberOfSources
org.apache.beam.sdk.io.aws2.kinesis.RateLimitPolicyFactoryTest ‑ defaultRateLimiterShouldUseBackoffs
org.apache.beam.sdk.io.aws2.kinesis.RecordFilterTest ‑ shouldFilterOutRecordsBeforeOrAtCheckpoint
org.apache.beam.sdk.io.aws2.kinesis.RecordFilterTest ‑ shouldNotFailOnEmptyList
org.apache.beam.sdk.io.aws2.kinesis.RecordsAggregatorTest ‑ testAggregationCompatibilityWithKcl
org.apache.beam.sdk.io.aws2.kinesis.RecordsAggregatorTest ‑ testGetRequestEntryAndReset
org.apache.beam.sdk.io.aws2.kinesis.RecordsAggregatorTest ‑ testHasCapacity
org.apache.beam.sdk.io.aws2.kinesis.RecordsAggregatorTest ‑ testRejectRecordIfSizeExceeded
org.apache.beam.sdk.io.aws2.kinesis.RecordsAggregatorTest ‑ testSizeIncrement
org.apache.beam.sdk.io.aws2.kinesis.RecordsAggregatorTest ‑ testSizeIncrementOfKey
org.apache.beam.sdk.io.aws2.kinesis.ShardCheckpointTest ‑ testComparisonWithExtendedSequenceNumber
org.apache.beam.sdk.io.aws2.kinesis.ShardCheckpointTest ‑ testComparisonWithTimestamp
org.apache.beam.sdk.io.aws2.kinesis.ShardCheckpointTest ‑ testEquals
org.apache.beam.sdk.io.aws2.kinesis.ShardCheckpointTest ‑ testProvidingShardIterator
org.apache.beam.sdk.io.aws2.kinesis.ShardListingUtilsTest ‑ shouldListAllShardsForLatest
org.apache.beam.sdk.io.aws2.kinesis.ShardListingUtilsTest ‑ shouldListAllShardsForTimestampBeforeStreamCreationTimestamp
org.apache.beam.sdk.io.aws2.kinesis.ShardListingUtilsTest ‑ shouldListAllShardsForTimestampOutsideStreamRetentionAfterStreamCreationTimestamp
org.apache.beam.sdk.io.aws2.kinesis.ShardListingUtilsTest ‑ shouldListAllShardsForTimestampWithRetriedDescribeStreamSummaryCallAfterStreamCreationTimestamp
org.apache.beam.sdk.io.aws2.kinesis.ShardListingUtilsTest ‑ shouldListAllShardsForTimestampWithinStreamRetentionAfterStreamCreationTimestamp
org.apache.beam.sdk.io.aws2.kinesis.ShardListingUtilsTest ‑ shouldListAllShardsForTrimHorizon
org.apache.beam.sdk.io.aws2.kinesis.ShardListingUtilsTest ‑ shouldListAllShardsForTrimHorizonWithPagedResults
org.apache.beam.sdk.io.aws2.kinesis.ShardListingUtilsTest ‑ shouldThrowLimitExceededExceptionForShardListing
org.apache.beam.sdk.io.aws2.kinesis.ShardListingUtilsTest ‑ shouldThrowProvisionedThroughputExceededExceptionForShardListing
org.apache.beam.sdk.io.aws2.kinesis.ShardListingUtilsTest ‑ shouldThrowServiceErrorForShardListing
org.apache.beam.sdk.io.aws2.kinesis.ShardReadersPoolExtendedTest ‑ poolWatermarkReturnsTsOfOldestAcknowledgedRecord
org.apache.beam.sdk.io.aws2.kinesis.ShardReadersPoolExtendedTest ‑ testNextRecordReturnsDeAggregatedRecords
org.apache.beam.sdk.io.aws2.kinesis.ShardReadersPoolExtendedTest ‑ testNextRecordReturnsDeAggregatedRecordsWhenStartedAfterSeqNum
org.apache.beam.sdk.io.aws2.kinesis.ShardReadersPoolExtendedTest ‑ testNextRecordReturnsNonAggregatedRecordsIfSubSeqNumIsPositive
org.apache.beam.sdk.io.aws2.kinesis.ShardReadersPoolExtendedTest ‑ testNextRecordReturnsRecords
org.apache.beam.sdk.io.aws2.kinesis.ShardReadersPoolExtendedTest ‑ testNextRecordReturnsRecordsWhenStartedAtLatest
org.apache.beam.sdk.io.aws2.kinesis.ShardReadersPoolExtendedTest ‑ testNextRecordReturnsRecordsWhenStartedAtTrimHorizon
org.apache.beam.sdk.io.aws2.kinesis.ShardReadersPoolTest ‑ shouldCallRateLimitPolicy
org.apache.beam.sdk.io.aws2.kinesis.ShardReadersPoolTest ‑ shouldCheckpointReadRecords
org.apache.beam.sdk.io.aws2.kinesis.ShardReadersPoolTest ‑ shouldForgetClosedShardIterator
org.apache.beam.sdk.io.aws2.kinesis.ShardReadersPoolTest ‑ shouldInterruptKinesisReadingAndStopShortly
org.apache.beam.sdk.io.aws2.kinesis.ShardReadersPoolTest ‑ shouldInterruptPuttingRecordsToQueueAndStopShortly
org.apache.beam.sdk.io.aws2.kinesis.ShardReadersPoolTest ‑ shouldReturnAbsentOptionalWhenNoRecords
org.apache.beam.sdk.io.aws2.kinesis.ShardReadersPoolTest ‑ shouldReturnAbsentOptionalWhenStartedWithNoIterators
org.apache.beam.sdk.io.aws2.kinesis.ShardReadersPoolTest ‑ shouldReturnAllRecords
org.apache.beam.sdk.io.aws2.kinesis.ShardReadersPoolTest ‑ shouldReturnTheLeastWatermarkOfAllShards
org.apache.beam.sdk.io.aws2.kinesis.ShardReadersPoolTest ‑ shouldReturnTheOldestFromLatestRecordTimestampOfAllShards
org.apache.beam.sdk.io.aws2.kinesis.ShardReadersPoolTest ‑ shouldStartReadingSuccessiveShardsAfterReceivingShardClosedException
org.apache.beam.sdk.io.aws2.kinesis.ShardReadersPoolTest ‑ shouldStopReadersPoolAlsoWhenExceptionsOccurDuringStopping
org.apache.beam.sdk.io.aws2.kinesis.ShardReadersPoolTest ‑ shouldStopReadersPoolWhenLastShardReaderStopped
org.apache.beam.sdk.io.aws2.kinesis.ShardReadersPoolTest ‑ shouldStopReadingShardAfterReceivingShardClosedException
org.apache.beam.sdk.io.aws2.kinesis.ShardRecordsIteratorTest ‑ conformingRecordsMovesCheckpoint
org.apache.beam.sdk.io.aws2.kinesis.ShardRecordsIteratorTest ‑ goesThroughAvailableRecords
org.apache.beam.sdk.io.aws2.kinesis.ShardRecordsIteratorTest ‑ refreshesExpiredIterator
org.apache.beam.sdk.io.aws2.kinesis.ShardRecordsIteratorTest ‑ tracksLatestRecordTimestamp
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldCountBytesWhenMultipleDataPointsReturned
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldCountBytesWhenSingleDataPointReturned
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldHandleExpiredIterationExceptionForGetShardIterator
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldHandleExpiredIterationExceptionForShardListing
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldHandleLimitExceededExceptionForGetBacklogBytes
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldHandleLimitExceededExceptionForGetShardIterator
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldHandleLimitExceededExceptionForShardListing
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldHandleNotRetryableClientErrorForGetBacklogBytes
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldHandleNotRetryableClientErrorForGetShardIterator
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldHandleProvisionedThroughputExceededExceptionForGetBacklogBytes
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldHandleProvisionedThroughputExceededExceptionForGetShardIterator
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldHandleProvisionedThroughputExceededExceptionForShardListing
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldHandleRetryableClientErrorForGetBacklogBytes
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldHandleRetryableClientErrorForGetShardIterator
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldHandleRetryableClientErrorForShardListing
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldHandleServiceErrorForGetBacklogBytes
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldHandleServiceErrorForGetShardIterator
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldHandleServiceErrorForShardListing
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldHandleUnexpectedExceptionForShardListing
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldListAllShardsForExclusiveStartShardId
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldNotCallCloudWatchWhenSpecifiedPeriodTooShort
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldReturnIteratorStartingWithSequenceNumber
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldReturnIteratorStartingtimestamp
org.apache.beam.sdk.io.aws2.kinesis.SimplifiedKinesisClientTest ‑ shouldReturnLimitedNumberOfRecords
org.apache.beam.sdk.io.aws2.kinesis.TimeUtilTest ‑ shouldConvertToJavaInstant
org.apache.beam.sdk.io.aws2.kinesis.TimeUtilTest ‑ shouldConvertToJodaInstant
org.apache.beam.sdk.io.aws2.kinesis.TimeUtilTest ‑ shouldGiveMinTs
org.apache.beam.sdk.io.aws2.kinesis.WatermarkPolicyTest ‑ shouldAdvanceWatermarkToNowWithProcessingTimePolicy
org.apache.beam.sdk.io.aws2.kinesis.WatermarkPolicyTest ‑ shouldAdvanceWatermarkWhenThereAreNoIncomingRecords
org.apache.beam.sdk.io.aws2.kinesis.WatermarkPolicyTest ‑ shouldAdvanceWatermarkWithCustomTimePolicy
org.apache.beam.sdk.io.aws2.kinesis.WatermarkPolicyTest ‑ shouldAdvanceWatermarkWithTheArrivalTimeFromKinesisRecords
org.apache.beam.sdk.io.aws2.kinesis.WatermarkPolicyTest ‑ shouldOnlyAdvanceTheWatermark
org.apache.beam.sdk.io.aws2.kinesis.WatermarkPolicyTest ‑ shouldUpdateWatermarkParameters
org.apache.beam.sdk.io.aws2.options.AwsModuleTest ‑ testAwsCredentialsProviderSerDe
org.apache.beam.sdk.io.aws2.options.AwsModuleTest ‑ testObjectMapperIsAbleToFindModule
org.apache.beam.sdk.io.aws2.options.AwsModuleTest ‑ testProfileCredentialsProviderSerDeWithCustomDefaultProfile
org.apache.beam.sdk.io.aws2.options.AwsModuleTest ‑ testProfileCredentialsProviderSerDeWithCustomProfile
org.apache.beam.sdk.io.aws2.options.AwsModuleTest ‑ testProfileCredentialsProviderSerDeWithDefaultProfile
org.apache.beam.sdk.io.aws2.options.AwsModuleTest ‑ testProfileCredentialsProviderSerDeWithUnknownProfile
org.apache.beam.sdk.io.aws2.options.AwsModuleTest ‑ testProxyConfigurationSerDe
org.apache.beam.sdk.io.aws2.options.AwsModuleTest ‑ testStaticCredentialsProviderSerDe
org.apache.beam.sdk.io.aws2.options.AwsModuleTest ‑ testStsAssumeRoleCredentialsProviderSerDe
org.apache.beam.sdk.io.aws2.options.AwsModuleTest ‑ testStsAssumeRoleWithWebIdentityCredentialsProviderSerDe
org.apache.beam.sdk.io.aws2.options.AwsOptionsTest ‑ testSerializeDeserializeDefaults
org.apache.beam.sdk.io.aws2.options.AwsOptionsTest ‑ testSetAwsCredentialsProvider
org.apache.beam.sdk.io.aws2.options.AwsOptionsTest ‑ testSetAwsRegion
org.apache.beam.sdk.io.aws2.options.AwsOptionsTest ‑ testSetEndpoint
org.apache.beam.sdk.io.aws2.options.AwsOptionsTest ‑ testSetHttpClientConfiguration
org.apache.beam.sdk.io.aws2.options.AwsOptionsTest ‑ testSetProxyConfiguration
org.apache.beam.sdk.io.aws2.options.AwsSerializableUtilsTest ‑ testAwsCredentialsProviderSerialization
org.apache.beam.sdk.io.aws2.options.AwsSerializableUtilsTest ‑ testFailOnAwsCredentialsProviderDeserialization
org.apache.beam.sdk.io.aws2.options.AwsSerializableUtilsTest ‑ testFailOnAwsCredentialsProviderSerialization
org.apache.beam.sdk.io.aws2.options.S3OptionsTest ‑ testSerializeDeserializeDefaults
org.apache.beam.sdk.io.aws2.options.S3OptionsTest ‑ testSetS3ClientFactoryClass
org.apache.beam.sdk.io.aws2.options.S3OptionsTest ‑ testSetS3StorageClass
org.apache.beam.sdk.io.aws2.options.S3OptionsTest ‑ testSetS3ThreadPoolSize
org.apache.beam.sdk.io.aws2.options.S3OptionsTest ‑ testSetS3UploadBufferSizeBytes
org.apache.beam.sdk.io.aws2.options.S3OptionsTest ‑ testSetSSEAlgorithm
org.apache.beam.sdk.io.aws2.options.S3OptionsTest ‑ testSetSSECustomerKey
org.apache.beam.sdk.io.aws2.options.S3OptionsTest ‑ testSetSSEKMSKeyId
org.apache.beam.sdk.io.aws2.s3.DefaultS3ClientBuilderFactoryTest ‑ testEmptyOptions
org.apache.beam.sdk.io.aws2.s3.DefaultS3ClientBuilderFactoryTest ‑ testSetCredentialsProvider
org.apache.beam.sdk.io.aws2.s3.DefaultS3ClientBuilderFactoryTest ‑ testSetEndpoint
org.apache.beam.sdk.io.aws2.s3.DefaultS3ClientBuilderFactoryTest ‑ testSetProxyConfiguration
org.apache.beam.sdk.io.aws2.s3.DefaultS3ClientBuilderFactoryTest ‑ testSetRegion
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ deleteThousandsOfObjectsInMultipleBuckets
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ deleteThousandsOfObjectsInMultipleBucketsWithS3Options
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ matchGlob
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ matchGlobWithSlashes
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ matchNonGlob
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ matchNonGlobForbidden
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ matchNonGlobForbiddenWithS3Options
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ matchNonGlobNotFound
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ matchNonGlobNotFoundWithS3Options
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ matchNonGlobNotReadSeekEfficient
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ matchNonGlobNotReadSeekEfficientWithS3Options
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ matchNonGlobNullContentEncoding
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ matchNonGlobNullContentEncodingWithOptions
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ matchNonGlobWithS3Options
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ matchVariousInvokeThreadPool
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ testAtomicCopy
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ testAtomicCopyWithS3Options
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ testCopy
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ testCopyWithS3Options
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ testGetPathStyleAccessEnabled
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ testGetPathStyleAccessEnabledWithS3Options
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ testGetScheme
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ testGetSchemeWithS3Options
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ testMultipartCopy
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ testMultipartCopyWithS3Options
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ testReportLineageOnBucket
org.apache.beam.sdk.io.aws2.s3.S3FileSystemTest ‑ testWriteAndRead
org.apache.beam.sdk.io.aws2.s3.S3ResourceIdTest ‑ testBucketParsing
org.apache.beam.sdk.io.aws2.s3.S3ResourceIdTest ‑ testEquals
org.apache.beam.sdk.io.aws2.s3.S3ResourceIdTest ‑ testGetCurrentDirectory
org.apache.beam.sdk.io.aws2.s3.S3ResourceIdTest ‑ testGetFilename
org.apache.beam.sdk.io.aws2.s3.S3ResourceIdTest ‑ testGetScheme
org.apache.beam.sdk.io.aws2.s3.S3ResourceIdTest ‑ testInvalidBucket
org.apache.beam.sdk.io.aws2.s3.S3ResourceIdTest ‑ testInvalidPathNoBucket
org.apache.beam.sdk.io.aws2.s3.S3ResourceIdTest ‑ testInvalidPathNoBucketAndSlash
org.apache.beam.sdk.io.aws2.s3.S3ResourceIdTest ‑ testIsDirectory
org.apache.beam.sdk.io.aws2.s3.S3ResourceIdTest ‑ testParentRelationship
org.apache.beam.sdk.io.aws2.s3.S3ResourceIdTest ‑ testResolve
org.apache.beam.sdk.io.aws2.s3.S3ResourceIdTest ‑ testResolveInvalidInputs
org.apache.beam.sdk.io.aws2.s3.S3ResourceIdTest ‑ testResolveInvalidNotDirectory
org.apache.beam.sdk.io.aws2.s3.S3ResourceIdTest ‑ testResolveParentToFile
org.apache.beam.sdk.io.aws2.s3.S3ResourceIdTest ‑ testResourceIdTester
org.apache.beam.sdk.io.aws2.s3.S3ResourceIdTest ‑ testS3ResolveWithFileBase
org.apache.beam.sdk.io.aws2.s3.S3ResourceIdTest ‑ testS3ResourceIdToString
org.apache.beam.sdk.io.aws2.s3.S3ResourceIdTest ‑ testSerialization
org.apache.beam.sdk.io.aws2.s3.S3WritableByteChannelTest ‑ testAtMostOne
org.apache.beam.sdk.io.aws2.s3.S3WritableByteChannelTest ‑ write
org.apache.beam.sdk.io.aws2.s3.S3WritableByteChannelTest ‑ writeWithS3Options
org.apache.beam.sdk.io.aws2.s3.SSECustomerKeyTest ‑ testBuild
org.apache.beam.sdk.io.aws2.s3.SSECustomerKeyTest ‑ testJsonSerializeDeserialize
org.apache.beam.sdk.io.aws2.schemas.AwsSchemaProviderTest ‑ testAwsExampleFromRow
org.apache.beam.sdk.io.aws2.schemas.AwsSchemaProviderTest ‑ testAwsExampleSchema
org.apache.beam.sdk.io.aws2.schemas.AwsSchemaProviderTest ‑ testAwsExampleToRow
org.apache.beam.sdk.io.aws2.schemas.AwsSchemaProviderTest ‑ testFailFromRowOnUnknownField
org.apache.beam.sdk.io.aws2.schemas.AwsSchemaProviderTest ‑ testFromRowSerializable
org.apache.beam.sdk.io.aws2.schemas.AwsSchemaProviderTest ‑ testFromRowWithPartialSchema
org.apache.beam.sdk.io.aws2.schemas.AwsSchemaProviderTest ‑ testRecursiveSchema
org.apache.beam.sdk.io.aws2.schemas.AwsSchemaProviderTest ‑ testSampleFromRow
org.apache.beam.sdk.io.aws2.schemas.AwsSchemaProviderTest ‑ testSampleSchema
org.apache.beam.sdk.io.aws2.schemas.AwsSchemaProviderTest ‑ testSampleToRow
org.apache.beam.sdk.io.aws2.schemas.AwsSchemaProviderTest ‑ testToRowSerializable
org.apache.beam.sdk.io.aws2.schemas.AwsSchemaUtilsTest ‑ generateBuilderFactory
org.apache.beam.sdk.io.aws2.sns.SnsIOTest ‑ testFailOnTopicValidation
org.apache.beam.sdk.io.aws2.sns.SnsIOTest ‑ testSkipTopicValidation
org.apache.beam.sdk.io.aws2.sns.SnsIOTest ‑ testWriteWithTopicArn
org.apache.beam.sdk.io.aws2.sns.SnsIOTest ‑ testWriteWithoutTopicArn
org.apache.beam.sdk.io.aws2.sqs.SqsIOReadTest ‑ testReadOnce
org.apache.beam.sdk.io.aws2.sqs.SqsIOWriteBatchesTest ‑ testSchemaEntryMapper
org.apache.beam.sdk.io.aws2.sqs.SqsIOWriteBatchesTest ‑ testWrite
org.apache.beam.sdk.io.aws2.sqs.SqsIOWriteBatchesTest ‑ testWriteBatches
org.apache.beam.sdk.io.aws2.sqs.SqsIOWriteBatchesTest ‑ testWriteBatchesFailure
org.apache.beam.sdk.io.aws2.sqs.SqsIOWriteBatchesTest ‑ testWriteBatchesPartialSuccess
org.apache.beam.sdk.io.aws2.sqs.SqsIOWriteBatchesTest ‑ testWriteBatchesToDynamic
org.apache.beam.sdk.io.aws2.sqs.SqsIOWriteBatchesTest ‑ testWriteBatchesToDynamicWithStrictTimeout
org.apache.beam.sdk.io.aws2.sqs.SqsIOWriteBatchesTest ‑ testWriteBatchesToDynamicWithStrictTimeoutAtHighVolume
org.apache.beam.sdk.io.aws2.sqs.SqsIOWriteBatchesTest ‑ testWriteBatchesToDynamicWithTimeout
org.apache.beam.sdk.io.aws2.sqs.SqsIOWriteBatchesTest ‑ testWriteBatchesWithStrictTimeout
org.apache.beam.sdk.io.aws2.sqs.SqsIOWriteBatchesTest ‑ testWriteBatchesWithTimeout
org.apache.beam.sdk.io.aws2.sqs.SqsIOWriteBatchesTest ‑ testWriteCustomBatches
org.apache.beam.sdk.io.aws2.sqs.SqsUnboundedReaderTest ‑ testAckDeletedMessage
org.apache.beam.sdk.io.aws2.sqs.SqsUnboundedReaderTest ‑ testCloseWithActiveCheckpoints
org.apache.beam.sdk.io.aws2.sqs.SqsUnboundedReaderTest ‑ testExtendDeletedMessage
org.apache.beam.sdk.io.aws2.sqs.SqsUnboundedReaderTest ‑ testReadManyMessages
org.apache.beam.sdk.io.aws2.sqs.SqsUnboundedReaderTest ‑ testReadOneMessage
org.apache.beam.sdk.io.aws2.sqs.SqsUnboundedReaderTest ‑ testRereadExpiredMessage
org.apache.beam.sdk.io.aws2.sqs.SqsUnboundedReaderTest ‑ testRestoreReaderFromCheckpoint
org.apache.beam.sdk.io.aws2.sqs.SqsUnboundedSourceTest ‑ testCheckpointCoderIsSane