You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@flink.apache.org by "Syinchwun Leo (JIRA)" <ji...@apache.org> on 2017/01/17 03:14:26 UTC

[jira] [Commented] (FLINK-5372) Fix RocksDBAsyncSnapshotTest.testCancelFullyAsyncCheckpoints()

    [ https://issues.apache.org/jira/browse/FLINK-5372?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel&focusedCommentId=15824885#comment-15824885 ] 

Syinchwun Leo commented on FLINK-5372:
--------------------------------------

When I run RocksDBStateBackend's test alone, it is OK. But when running Flink's whole test, it will be locked like the following:   
-------------------------------------------------------
 T E S T S
-------------------------------------------------------
Running org.apache.flink.contrib.streaming.state.RocksDBInitResetTest
Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.056 sec - in org.apache.flink.contrib.streaming.state.RocksDBInitResetTest
Running org.apache.flink.contrib.streaming.state.RocksDBStateBackendTest
Tests run: 25, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.961 sec - in org.apache.flink.contrib.streaming.state.RocksDBStateBackendTest
Running org.apache.flink.contrib.streaming.state.RocksDBStateBackendConfigTest
Tests run: 11, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.049 sec - in org.apache.flink.contrib.streaming.state.RocksDBStateBackendConfigTest
Running org.apache.flink.contrib.streaming.state.RocksDBMergeIteratorTest
Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.359 sec - in org.apache.flink.contrib.streaming.state.RocksDBMergeIteratorTest
Running org.apache.flink.contrib.streaming.state.RocksDBStateBackendFactoryTest
Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.002 sec - in org.apache.flink.contrib.streaming.state.RocksDBStateBackendFactoryTest
Running org.apache.flink.contrib.streaming.state.RocksDBAsyncSnapshotTest

No test result!!!!

> Fix RocksDBAsyncSnapshotTest.testCancelFullyAsyncCheckpoints()
> --------------------------------------------------------------
>
>                 Key: FLINK-5372
>                 URL: https://issues.apache.org/jira/browse/FLINK-5372
>             Project: Flink
>          Issue Type: Bug
>          Components: Streaming
>            Reporter: Aljoscha Krettek
>            Assignee: Aljoscha Krettek
>
> The test is currently {{@Ignored}}. We have to change {{AsyncCheckpointOperator}} to make sure that we can run fully asynchronously. Then, the test will still fail because the canceling behaviour was changed in the meantime.
> {code}
> public static class AsyncCheckpointOperator
>     extends AbstractStreamOperator<String>
>     implements OneInputStreamOperator<String, String> {
>     @Override
>     public void open() throws Exception {
>         super.open();
>         // also get the state in open, this way we are sure that it was created before
>         // we trigger the test checkpoint
>         ValueState<String> state = getPartitionedState(
>                 VoidNamespace.INSTANCE,
>                 VoidNamespaceSerializer.INSTANCE,
>                 new ValueStateDescriptor<>("count",
>                         StringSerializer.INSTANCE, "hello"));
>     }
>     @Override
>     public void processElement(StreamRecord<String> element) throws Exception {
>         // we also don't care
>         ValueState<String> state = getPartitionedState(
>                 VoidNamespace.INSTANCE,
>                 VoidNamespaceSerializer.INSTANCE,
>                 new ValueStateDescriptor<>("count",
>                         StringSerializer.INSTANCE, "hello"));
>         state.update(element.getValue());
>     }
>     @Override
>     public void snapshotState(StateSnapshotContext context) throws Exception {
>         // do nothing so that we don't block
>     }
> }
> {code}



--
This message was sent by Atlassian JIRA
(v6.3.4#6332)