Class FlinkMatchers

    • Method Detail

      • futureFailedWith

        public static <T,​E extends Throwable> org.apache.flink.core.testutils.FlinkMatchers.FutureFailedMatcher<T> futureFailedWith​(Class<E> exceptionType)
        Deprecated.
        Checks whether CompletableFuture completed already exceptionally with a specific exception type.
      • futureWillCompleteExceptionally

        public static <T,​E extends Throwable> org.apache.flink.core.testutils.FlinkMatchers.FutureWillFailMatcher<T> futureWillCompleteExceptionally​(Class<E> exceptionType,
                                                                                                                                                           Duration timeout)
        Deprecated.
        Checks whether CompletableFuture will completed exceptionally within a certain time.
      • futureWillCompleteExceptionally

        public static <T> org.apache.flink.core.testutils.FlinkMatchers.FutureWillFailMatcher<T> futureWillCompleteExceptionally​(Function<Throwable,​Boolean> exceptionCheck,
                                                                                                                                 Duration timeout,
                                                                                                                                 String checkDescription)
        Deprecated.
        Checks whether CompletableFuture will completed exceptionally within a certain time.
      • futureWillCompleteExceptionally

        public static <T> org.apache.flink.core.testutils.FlinkMatchers.FutureWillFailMatcher<T> futureWillCompleteExceptionally​(Duration timeout)
        Deprecated.
        Checks whether CompletableFuture will completed exceptionally within a certain time.
      • containsCause

        public static org.hamcrest.Matcher<Throwable> containsCause​(Class<? extends Throwable> failureCause)
        Deprecated.
        Checks for a Throwable that matches by class.
      • containsCause

        public static org.hamcrest.Matcher<Throwable> containsCause​(Throwable failureCause)
        Deprecated.
        Checks for a Throwable that matches by class and message.
      • containsMessage

        public static org.hamcrest.Matcher<Throwable> containsMessage​(String errorMessage)
        Deprecated.
        Checks for a Throwable that contains the expected error message.