Search in sources :

Example 1 with AssertionCompletedException

use of com.hazelcast.jet.pipeline.test.AssertionCompletedException in project hazelcast by hazelcast.

the class OrderedProcessingMergingStagesTest method when_hashJoin2_applied_primary_stream_order_is_preserved.

@Test
public void when_hashJoin2_applied_primary_stream_order_is_preserved() {
    int validatedItemCountPerGenerator = ITEM_COUNT;
    int eventsPerSecondPerGenerator = 5 * ITEM_COUNT;
    int generatorCount = 2;
    // Generate monotonic increasing items that are distinct for each generator.
    GeneratorFunction<Map.Entry<Long, Long>> generator1 = (ts, seq) -> Util.entry(0L, generatorCount * seq);
    GeneratorFunction<Map.Entry<Long, Long>> generator2 = (ts, seq) -> Util.entry(1L, generatorCount * seq + 1);
    StreamStage<Map.Entry<Long, Long>> srcStage = p.readFrom(itemsParallel(eventsPerSecondPerGenerator, Arrays.asList(generator1, generator2))).withIngestionTimestamps();
    BatchStage<Map.Entry<Long, Long>> batchStage = p.readFrom(TestSources.items(Util.entry(0L, 0L), Util.entry(1L, 0L)));
    BatchStage<Map.Entry<Long, Long>> batchStage2 = p.readFrom(TestSources.items(Util.entry(0L, 0L), Util.entry(1L, 0L)));
    StreamStage<Map.Entry<Long, Long>> joined = srcStage.hashJoin2(batchStage, JoinClause.onKeys(Map.Entry::getKey, Map.Entry::getKey), batchStage2, JoinClause.onKeys(Map.Entry::getKey, Map.Entry::getKey), (primary, stg1, stg2) -> primary).setLocalParallelism(HIGH_LOCAL_PARALLELISM);
    joined.groupingKey(Map.Entry::getKey).mapStateful(() -> create(generatorCount), this::orderValidator).writeTo(AssertionSinks.assertCollectedEventually(60, list -> {
        assertTrue("when", validatedItemCountPerGenerator <= list.size());
        assertFalse("There is some reordered items in the list", list.contains(false));
    }));
    Job job = hz.getJet().newJob(p);
    try {
        job.join();
        fail("Job should have completed with an AssertionCompletedException, but completed normally");
    } catch (CompletionException e) {
        String errorMsg = e.getCause().getMessage();
        assertTrue("Job was expected to complete with AssertionCompletedException, but completed with: " + e.getCause(), errorMsg.contains(AssertionCompletedException.class.getName()));
    }
}
Also used : AssertionSinks(com.hazelcast.jet.pipeline.test.AssertionSinks) Arrays(java.util.Arrays) BeforeClass(org.junit.BeforeClass) QuickTest(com.hazelcast.test.annotation.QuickTest) ParallelStreamP(com.hazelcast.jet.pipeline.test.ParallelStreamP) HazelcastSerialParametersRunnerFactory(com.hazelcast.test.HazelcastSerialParametersRunnerFactory) JetAssert.assertFalse(com.hazelcast.jet.core.test.JetAssert.assertFalse) JetAssert.assertTrue(com.hazelcast.jet.core.test.JetAssert.assertTrue) Map(java.util.Map) Nonnull(javax.annotation.Nonnull) Job(com.hazelcast.jet.Job) Before(org.junit.Before) UseParametersRunnerFactory(org.junit.runners.Parameterized.UseParametersRunnerFactory) HazelcastInstance(com.hazelcast.core.HazelcastInstance) AfterClass(org.junit.AfterClass) LongStream(java.util.stream.LongStream) JetTestSupport(com.hazelcast.jet.core.JetTestSupport) ProcessorMetaSupplier(com.hazelcast.jet.core.ProcessorMetaSupplier) Test(org.junit.Test) CompletionException(java.util.concurrent.CompletionException) Category(org.junit.experimental.categories.Category) Serializable(java.io.Serializable) Objects(java.util.Objects) JetAssert.fail(com.hazelcast.jet.core.test.JetAssert.fail) TestSources(com.hazelcast.jet.pipeline.test.TestSources) List(java.util.List) Collectors.toList(java.util.stream.Collectors.toList) GeneratorFunction(com.hazelcast.jet.pipeline.test.GeneratorFunction) Hazelcast(com.hazelcast.core.Hazelcast) AssertionCompletedException(com.hazelcast.jet.pipeline.test.AssertionCompletedException) LongAccumulator(com.hazelcast.jet.accumulator.LongAccumulator) Assert(org.junit.Assert) Util(com.hazelcast.jet.Util) AssertionCompletedException(com.hazelcast.jet.pipeline.test.AssertionCompletedException) CompletionException(java.util.concurrent.CompletionException) Job(com.hazelcast.jet.Job) QuickTest(com.hazelcast.test.annotation.QuickTest) Test(org.junit.Test)

Example 2 with AssertionCompletedException

use of com.hazelcast.jet.pipeline.test.AssertionCompletedException in project hazelcast by hazelcast.

the class OrderedProcessingMergingStagesTest method when_innerJoin_applied_primary_stream_order_is_preserved.

@Test
public void when_innerJoin_applied_primary_stream_order_is_preserved() {
    int validatedItemCountPerGenerator = ITEM_COUNT;
    int eventsPerSecondPerGenerator = 5 * ITEM_COUNT;
    int generatorCount = 2;
    // Generate monotonic increasing items that are distinct for each generator.
    GeneratorFunction<Map.Entry<Long, Long>> generator1 = (ts, seq) -> Util.entry(0L, generatorCount * seq);
    GeneratorFunction<Map.Entry<Long, Long>> generator2 = (ts, seq) -> Util.entry(1L, generatorCount * seq + 1);
    StreamStage<Map.Entry<Long, Long>> srcStage = p.readFrom(itemsParallel(eventsPerSecondPerGenerator, Arrays.asList(generator1, generator2))).withIngestionTimestamps().setLocalParallelism(HIGH_LOCAL_PARALLELISM);
    BatchStage<Map.Entry<Long, Long>> batchStage = p.readFrom(TestSources.items(Util.entry(0L, 0L), Util.entry(1L, 0L)));
    StreamStage<Map.Entry<Long, Long>> joined = srcStage.innerHashJoin(batchStage, JoinClause.onKeys(Map.Entry::getKey, Map.Entry::getKey), (primary, stg) -> primary).setLocalParallelism(LOW_LOCAL_PARALLELISM);
    joined.groupingKey(Map.Entry::getKey).mapStateful(() -> create(generatorCount), this::orderValidator).writeTo(AssertionSinks.assertCollectedEventually(60, list -> {
        assertTrue("when", validatedItemCountPerGenerator <= list.size());
        assertFalse("There is some reordered items in the list", list.contains(false));
    }));
    Job job = hz.getJet().newJob(p);
    try {
        job.join();
        fail("Job should have completed with an AssertionCompletedException, but completed normally");
    } catch (CompletionException e) {
        String errorMsg = e.getCause().getMessage();
        assertTrue("Job was expected to complete with AssertionCompletedException, but completed with: " + e.getCause(), errorMsg.contains(AssertionCompletedException.class.getName()));
    }
}
Also used : AssertionSinks(com.hazelcast.jet.pipeline.test.AssertionSinks) Arrays(java.util.Arrays) BeforeClass(org.junit.BeforeClass) QuickTest(com.hazelcast.test.annotation.QuickTest) ParallelStreamP(com.hazelcast.jet.pipeline.test.ParallelStreamP) HazelcastSerialParametersRunnerFactory(com.hazelcast.test.HazelcastSerialParametersRunnerFactory) JetAssert.assertFalse(com.hazelcast.jet.core.test.JetAssert.assertFalse) JetAssert.assertTrue(com.hazelcast.jet.core.test.JetAssert.assertTrue) Map(java.util.Map) Nonnull(javax.annotation.Nonnull) Job(com.hazelcast.jet.Job) Before(org.junit.Before) UseParametersRunnerFactory(org.junit.runners.Parameterized.UseParametersRunnerFactory) HazelcastInstance(com.hazelcast.core.HazelcastInstance) AfterClass(org.junit.AfterClass) LongStream(java.util.stream.LongStream) JetTestSupport(com.hazelcast.jet.core.JetTestSupport) ProcessorMetaSupplier(com.hazelcast.jet.core.ProcessorMetaSupplier) Test(org.junit.Test) CompletionException(java.util.concurrent.CompletionException) Category(org.junit.experimental.categories.Category) Serializable(java.io.Serializable) Objects(java.util.Objects) JetAssert.fail(com.hazelcast.jet.core.test.JetAssert.fail) TestSources(com.hazelcast.jet.pipeline.test.TestSources) List(java.util.List) Collectors.toList(java.util.stream.Collectors.toList) GeneratorFunction(com.hazelcast.jet.pipeline.test.GeneratorFunction) Hazelcast(com.hazelcast.core.Hazelcast) AssertionCompletedException(com.hazelcast.jet.pipeline.test.AssertionCompletedException) LongAccumulator(com.hazelcast.jet.accumulator.LongAccumulator) Assert(org.junit.Assert) Util(com.hazelcast.jet.Util) AssertionCompletedException(com.hazelcast.jet.pipeline.test.AssertionCompletedException) CompletionException(java.util.concurrent.CompletionException) Job(com.hazelcast.jet.Job) QuickTest(com.hazelcast.test.annotation.QuickTest) Test(org.junit.Test)

Example 3 with AssertionCompletedException

use of com.hazelcast.jet.pipeline.test.AssertionCompletedException in project hazelcast by hazelcast.

the class OrderedStreamProcessingTest method when_source_is_parallel_2.

@Test
public void when_source_is_parallel_2() {
    int validatedItemCountPerGenerator = ITEM_COUNT;
    int eventsPerSecondPerGenerator = 5 * ITEM_COUNT;
    int generatorCount = 4;
    // Generate monotonic increasing items that are distinct for each generator.
    GeneratorFunction<Long> generator1 = (ts, seq) -> generatorCount * seq;
    GeneratorFunction<Long> generator2 = (ts, seq) -> generatorCount * seq + 1;
    GeneratorFunction<Long> generator3 = (ts, seq) -> generatorCount * seq + 2;
    GeneratorFunction<Long> generator4 = (ts, seq) -> generatorCount * seq + 3;
    List<Long> sequence1 = LongStream.range(0, validatedItemCountPerGenerator).map(i -> generatorCount * i).boxed().collect(toList());
    List<Long> sequence2 = LongStream.range(0, validatedItemCountPerGenerator).map(i -> generatorCount * i + 1).boxed().collect(toList());
    List<Long> sequence3 = LongStream.range(0, validatedItemCountPerGenerator).map(i -> generatorCount * i + 2).boxed().collect(toList());
    List<Long> sequence4 = LongStream.range(0, validatedItemCountPerGenerator).map(i -> generatorCount * i + 3).boxed().collect(toList());
    StreamStage<Long> srcStage = p.readFrom(itemsParallel(eventsPerSecondPerGenerator, Arrays.asList(generator1, generator2, generator3, generator4))).withIngestionTimestamps();
    StreamStage<Long> applied = srcStage.apply(transform);
    applied.filter(i -> i % generatorCount == 0).writeTo(AssertionSinks.assertCollectedEventually(60, list -> Assert.assertArrayEquals(list.toArray(), sequence1.toArray())));
    applied.filter(i -> i % generatorCount == 1).writeTo(AssertionSinks.assertCollectedEventually(60, list -> Assert.assertArrayEquals(list.toArray(), sequence2.toArray())));
    applied.filter(i -> i % generatorCount == 2).writeTo(AssertionSinks.assertCollectedEventually(60, list -> Assert.assertArrayEquals(list.toArray(), sequence3.toArray())));
    applied.filter(i -> i % generatorCount == 3).writeTo(AssertionSinks.assertCollectedEventually(60, list -> Assert.assertArrayEquals(list.toArray(), sequence4.toArray())));
    Job job = jet.newJob(p);
    try {
        job.join();
        fail("Job should have completed with an AssertionCompletedException, but completed normally");
    } catch (CompletionException e) {
        String errorMsg = e.getCause().getMessage();
        assertTrue("Job was expected to complete with AssertionCompletedException, but completed with: " + e.getCause(), errorMsg.contains(AssertionCompletedException.class.getName()));
    }
}
Also used : AssertionSinks(com.hazelcast.jet.pipeline.test.AssertionSinks) Arrays(java.util.Arrays) JetInstance(com.hazelcast.jet.JetInstance) BeforeClass(org.junit.BeforeClass) RunWith(org.junit.runner.RunWith) Parameters(org.junit.runners.Parameterized.Parameters) Processors(com.hazelcast.jet.core.processor.Processors) ParallelStreamP(com.hazelcast.jet.pipeline.test.ParallelStreamP) HazelcastSerialParametersRunnerFactory(com.hazelcast.test.HazelcastSerialParametersRunnerFactory) JetAssert.assertFalse(com.hazelcast.jet.core.test.JetAssert.assertFalse) JetAssert.assertTrue(com.hazelcast.jet.core.test.JetAssert.assertTrue) Nonnull(javax.annotation.Nonnull) Job(com.hazelcast.jet.Job) Before(org.junit.Before) UseParametersRunnerFactory(org.junit.runners.Parameterized.UseParametersRunnerFactory) PredicateEx(com.hazelcast.function.PredicateEx) FunctionEx(com.hazelcast.function.FunctionEx) AfterClass(org.junit.AfterClass) LongStream(java.util.stream.LongStream) HazelcastParametrizedRunner(com.hazelcast.test.HazelcastParametrizedRunner) JetTestSupport(com.hazelcast.jet.core.JetTestSupport) Parameter(org.junit.runners.Parameterized.Parameter) ProcessorMetaSupplier(com.hazelcast.jet.core.ProcessorMetaSupplier) Collection(java.util.Collection) Test(org.junit.Test) CompletionException(java.util.concurrent.CompletionException) Traversers(com.hazelcast.jet.Traversers) Serializable(java.io.Serializable) Objects(java.util.Objects) JetAssert.fail(com.hazelcast.jet.core.test.JetAssert.fail) TestSources(com.hazelcast.jet.pipeline.test.TestSources) List(java.util.List) Collectors.toList(java.util.stream.Collectors.toList) GeneratorFunction(com.hazelcast.jet.pipeline.test.GeneratorFunction) Hazelcast(com.hazelcast.core.Hazelcast) AssertionCompletedException(com.hazelcast.jet.pipeline.test.AssertionCompletedException) LongAccumulator(com.hazelcast.jet.accumulator.LongAccumulator) Functions.wholeItem(com.hazelcast.function.Functions.wholeItem) Assert(org.junit.Assert) AssertionCompletedException(com.hazelcast.jet.pipeline.test.AssertionCompletedException) CompletionException(java.util.concurrent.CompletionException) Job(com.hazelcast.jet.Job) Test(org.junit.Test)

Example 4 with AssertionCompletedException

use of com.hazelcast.jet.pipeline.test.AssertionCompletedException in project hazelcast by hazelcast.

the class OrderedStreamProcessingTest method when_source_is_parallel.

@Test
public void when_source_is_parallel() {
    int validatedItemCountPerGenerator = ITEM_COUNT;
    int eventsPerSecondPerGenerator = 5 * ITEM_COUNT;
    int generatorCount = 4;
    // Generate monotonic increasing items that are distinct for each generator.
    GeneratorFunction<Long> generator1 = (ts, seq) -> generatorCount * seq;
    GeneratorFunction<Long> generator2 = (ts, seq) -> generatorCount * seq + 1;
    GeneratorFunction<Long> generator3 = (ts, seq) -> generatorCount * seq + 2;
    GeneratorFunction<Long> generator4 = (ts, seq) -> generatorCount * seq + 3;
    StreamStage<Long> srcStage = p.readFrom(itemsParallel(eventsPerSecondPerGenerator, Arrays.asList(generator1, generator2, generator3, generator4))).withIngestionTimestamps();
    StreamStage<Long> applied = srcStage.apply(transform);
    applied.mapStateful(() -> create(generatorCount), this::orderValidator).writeTo(AssertionSinks.assertCollectedEventually(60, list -> {
        assertTrue("when", validatedItemCountPerGenerator <= list.size());
        assertFalse("There is some reordered items in the list", list.contains(false));
    }));
    Job job = jet.newJob(p);
    try {
        job.join();
        fail("Job should have completed with an AssertionCompletedException, but completed normally");
    } catch (CompletionException e) {
        String errorMsg = e.getCause().getMessage();
        assertTrue("Job was expected to complete with AssertionCompletedException, but completed with: " + e.getCause(), errorMsg.contains(AssertionCompletedException.class.getName()));
    }
}
Also used : AssertionSinks(com.hazelcast.jet.pipeline.test.AssertionSinks) Arrays(java.util.Arrays) JetInstance(com.hazelcast.jet.JetInstance) BeforeClass(org.junit.BeforeClass) RunWith(org.junit.runner.RunWith) Parameters(org.junit.runners.Parameterized.Parameters) Processors(com.hazelcast.jet.core.processor.Processors) ParallelStreamP(com.hazelcast.jet.pipeline.test.ParallelStreamP) HazelcastSerialParametersRunnerFactory(com.hazelcast.test.HazelcastSerialParametersRunnerFactory) JetAssert.assertFalse(com.hazelcast.jet.core.test.JetAssert.assertFalse) JetAssert.assertTrue(com.hazelcast.jet.core.test.JetAssert.assertTrue) Nonnull(javax.annotation.Nonnull) Job(com.hazelcast.jet.Job) Before(org.junit.Before) UseParametersRunnerFactory(org.junit.runners.Parameterized.UseParametersRunnerFactory) PredicateEx(com.hazelcast.function.PredicateEx) FunctionEx(com.hazelcast.function.FunctionEx) AfterClass(org.junit.AfterClass) LongStream(java.util.stream.LongStream) HazelcastParametrizedRunner(com.hazelcast.test.HazelcastParametrizedRunner) JetTestSupport(com.hazelcast.jet.core.JetTestSupport) Parameter(org.junit.runners.Parameterized.Parameter) ProcessorMetaSupplier(com.hazelcast.jet.core.ProcessorMetaSupplier) Collection(java.util.Collection) Test(org.junit.Test) CompletionException(java.util.concurrent.CompletionException) Traversers(com.hazelcast.jet.Traversers) Serializable(java.io.Serializable) Objects(java.util.Objects) JetAssert.fail(com.hazelcast.jet.core.test.JetAssert.fail) TestSources(com.hazelcast.jet.pipeline.test.TestSources) List(java.util.List) Collectors.toList(java.util.stream.Collectors.toList) GeneratorFunction(com.hazelcast.jet.pipeline.test.GeneratorFunction) Hazelcast(com.hazelcast.core.Hazelcast) AssertionCompletedException(com.hazelcast.jet.pipeline.test.AssertionCompletedException) LongAccumulator(com.hazelcast.jet.accumulator.LongAccumulator) Functions.wholeItem(com.hazelcast.function.Functions.wholeItem) Assert(org.junit.Assert) AssertionCompletedException(com.hazelcast.jet.pipeline.test.AssertionCompletedException) CompletionException(java.util.concurrent.CompletionException) Job(com.hazelcast.jet.Job) Test(org.junit.Test)

Example 5 with AssertionCompletedException

use of com.hazelcast.jet.pipeline.test.AssertionCompletedException in project hazelcast by hazelcast.

the class KinesisIntegrationTest method customProjection.

@Test
@Category(SerialTest.class)
public void customProjection() {
    HELPER.createStream(1);
    sendMessages();
    Long expectedPerSequenceNo = 1L;
    try {
        Pipeline pipeline = Pipeline.create();
        StreamSource<String> source = kinesisSource().withProjectionFn((r, s) -> {
            byte[] payload = new byte[r.getData().remaining()];
            r.getData().get(payload);
            return r.getSequenceNumber();
        }).build();
        pipeline.readFrom(source).withoutTimestamps().groupingKey(r -> r).rollingAggregate(counting()).apply(assertCollectedEventually(ASSERT_TRUE_EVENTUALLY_TIMEOUT, results -> {
            assertEquals(MESSAGES, results.size());
            results.forEach(v -> assertEquals(expectedPerSequenceNo, v.getValue()));
        }));
        hz().getJet().newJob(pipeline).join();
        fail("Expected exception not thrown");
    } catch (CompletionException ce) {
        Throwable cause = peel(ce);
        assertTrue(cause instanceof JetException);
        assertTrue(cause.getCause() instanceof AssertionCompletedException);
    }
}
Also used : Shard(com.amazonaws.services.kinesis.model.Shard) AggregateOperations.counting(com.hazelcast.jet.aggregate.AggregateOperations.counting) BeforeClass(org.junit.BeforeClass) AT_SEQUENCE_NUMBER(com.amazonaws.services.kinesis.model.ShardIteratorType.AT_SEQUENCE_NUMBER) JobProxy(com.hazelcast.jet.impl.JobProxy) StreamSource(com.hazelcast.jet.pipeline.StreamSource) SDKGlobalConfiguration(com.amazonaws.SDKGlobalConfiguration) AmazonKinesisAsync(com.amazonaws.services.kinesis.AmazonKinesisAsync) JetException(com.hazelcast.jet.JetException) PutRecordsResult(com.amazonaws.services.kinesis.model.PutRecordsResult) Map(java.util.Map) AwsConfig(com.hazelcast.jet.kinesis.impl.AwsConfig) AT_TIMESTAMP(com.amazonaws.services.kinesis.model.ShardIteratorType.AT_TIMESTAMP) Assert.fail(org.junit.Assert.fail) JobStatus(com.hazelcast.jet.core.JobStatus) Tuple2(com.hazelcast.jet.datamodel.Tuple2) Job(com.hazelcast.jet.Job) Service(org.testcontainers.containers.localstack.LocalStackContainer.Service) TRIM_HORIZON(com.amazonaws.services.kinesis.model.ShardIteratorType.TRIM_HORIZON) DockerImageName.parse(org.testcontainers.utility.DockerImageName.parse) WindowDefinition(com.hazelcast.jet.pipeline.WindowDefinition) Logger(com.hazelcast.logging.Logger) LATEST(com.amazonaws.services.kinesis.model.ShardIteratorType.LATEST) NightlyTest(com.hazelcast.test.annotation.NightlyTest) AfterClass(org.junit.AfterClass) Assertions.assertCollectedEventually(com.hazelcast.jet.pipeline.test.Assertions.assertCollectedEventually) Pipeline(com.hazelcast.jet.pipeline.Pipeline) JobConfig(com.hazelcast.jet.config.JobConfig) Set(java.util.Set) Assert.assertTrue(org.junit.Assert.assertTrue) Test(org.junit.Test) CompletionException(java.util.concurrent.CompletionException) Category(org.junit.experimental.categories.Category) LocalStackContainer(org.testcontainers.containers.localstack.LocalStackContainer) Collectors(java.util.stream.Collectors) List(java.util.List) AFTER_SEQUENCE_NUMBER(com.amazonaws.services.kinesis.model.ShardIteratorType.AFTER_SEQUENCE_NUMBER) Ignore(org.junit.Ignore) AssertionCompletedException(com.hazelcast.jet.pipeline.test.AssertionCompletedException) ExceptionUtil.peel(com.hazelcast.jet.impl.util.ExceptionUtil.peel) Assert.assertFalse(org.junit.Assert.assertFalse) SerialTest(com.hazelcast.jet.test.SerialTest) DockerClientFactory(org.testcontainers.DockerClientFactory) Assume.assumeTrue(org.junit.Assume.assumeTrue) ProcessingGuarantee(com.hazelcast.jet.config.ProcessingGuarantee) Collections(java.util.Collections) SECONDS(java.util.concurrent.TimeUnit.SECONDS) Assert.assertEquals(org.junit.Assert.assertEquals) AssertionCompletedException(com.hazelcast.jet.pipeline.test.AssertionCompletedException) CompletionException(java.util.concurrent.CompletionException) JetException(com.hazelcast.jet.JetException) Pipeline(com.hazelcast.jet.pipeline.Pipeline) Category(org.junit.experimental.categories.Category) NightlyTest(com.hazelcast.test.annotation.NightlyTest) Test(org.junit.Test) SerialTest(com.hazelcast.jet.test.SerialTest)

Aggregations

Job (com.hazelcast.jet.Job)11 AssertionCompletedException (com.hazelcast.jet.pipeline.test.AssertionCompletedException)11 CompletionException (java.util.concurrent.CompletionException)11 AfterClass (org.junit.AfterClass)11 BeforeClass (org.junit.BeforeClass)11 Test (org.junit.Test)11 List (java.util.List)10 Hazelcast (com.hazelcast.core.Hazelcast)9 LongAccumulator (com.hazelcast.jet.accumulator.LongAccumulator)9 JetTestSupport (com.hazelcast.jet.core.JetTestSupport)9 JetAssert.assertFalse (com.hazelcast.jet.core.test.JetAssert.assertFalse)9 JetAssert.assertTrue (com.hazelcast.jet.core.test.JetAssert.assertTrue)9 JetAssert.fail (com.hazelcast.jet.core.test.JetAssert.fail)9 AssertionSinks (com.hazelcast.jet.pipeline.test.AssertionSinks)9 HazelcastSerialParametersRunnerFactory (com.hazelcast.test.HazelcastSerialParametersRunnerFactory)9 Serializable (java.io.Serializable)9 Arrays (java.util.Arrays)9 LongStream (java.util.stream.LongStream)9 Before (org.junit.Before)9 UseParametersRunnerFactory (org.junit.runners.Parameterized.UseParametersRunnerFactory)9