You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@flink.apache.org by tz...@apache.org on 2020/05/15 11:09:07 UTC

[flink-statefun] 16/17: [hotfix] Remove unused code

This is an automated email from the ASF dual-hosted git repository.

tzulitai pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/flink-statefun.git

commit c49de86e946e1b1d46aa36cce22f61fa2e638198
Author: Igal Shilman <ig...@gmail.com>
AuthorDate: Tue May 5 23:18:33 2020 +0200

    [hotfix] Remove unused code
---
 .../flink/core/common/SerializablePredicate.java   | 23 ----------------------
 .../flink/statefun/flink/core/logger/Loggers.java  | 14 -------------
 2 files changed, 37 deletions(-)

diff --git a/statefun-flink/statefun-flink-core/src/main/java/org/apache/flink/statefun/flink/core/common/SerializablePredicate.java b/statefun-flink/statefun-flink-core/src/main/java/org/apache/flink/statefun/flink/core/common/SerializablePredicate.java
deleted file mode 100644
index 05e6c48..0000000
--- a/statefun-flink/statefun-flink-core/src/main/java/org/apache/flink/statefun/flink/core/common/SerializablePredicate.java
+++ /dev/null
@@ -1,23 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.flink.statefun.flink.core.common;
-
-import java.io.Serializable;
-import java.util.function.Predicate;
-
-public interface SerializablePredicate<T> extends Predicate<T>, Serializable {}
diff --git a/statefun-flink/statefun-flink-core/src/main/java/org/apache/flink/statefun/flink/core/logger/Loggers.java b/statefun-flink/statefun-flink-core/src/main/java/org/apache/flink/statefun/flink/core/logger/Loggers.java
index 948a808..aee7536 100644
--- a/statefun-flink/statefun-flink-core/src/main/java/org/apache/flink/statefun/flink/core/logger/Loggers.java
+++ b/statefun-flink/statefun-flink-core/src/main/java/org/apache/flink/statefun/flink/core/logger/Loggers.java
@@ -36,20 +36,6 @@ import org.apache.flink.util.ResourceGuard.Lease;
 public final class Loggers {
   private Loggers() {}
 
-  public static UnboundedFeedbackLogger<?> unboundedSpillableLogger(
-      IOManager ioManager,
-      int maxParallelism,
-      long inMemoryMaxBufferSize,
-      TypeSerializer<?> serializer,
-      Function<?, ?> keySelector) {
-
-    UnboundedFeedbackLoggerFactory<?> factory =
-        unboundedSpillableLoggerFactory(
-            ioManager, maxParallelism, inMemoryMaxBufferSize, serializer, keySelector);
-
-    return factory.create();
-  }
-
   public static UnboundedFeedbackLoggerFactory<?> unboundedSpillableLoggerFactory(
       IOManager ioManager,
       int maxParallelism,