You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@reef.apache.org by af...@apache.org on 2015/10/28 23:29:25 UTC

incubator-reef git commit: [REEF-879] Remove classes deprecated since 0.13 from reef-wake

Repository: incubator-reef
Updated Branches:
  refs/heads/master 709e217d3 -> a348df538


[REEF-879] Remove classes deprecated since 0.13 from reef-wake

This PR removes the following classes deprecated in 0.13.
 * reef/wake/IdentifierParser.java
 * wake/storage/FileHandlePool.java
 * wake/storage/ReadRequest.java
 * wake/storage/ReadResponse.java

JIRA:
  [REEF-879](https://issues.apache.org/jira/browse/REEF-879)

Pull request:
  This closes #595


Project: http://git-wip-us.apache.org/repos/asf/incubator-reef/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-reef/commit/a348df53
Tree: http://git-wip-us.apache.org/repos/asf/incubator-reef/tree/a348df53
Diff: http://git-wip-us.apache.org/repos/asf/incubator-reef/diff/a348df53

Branch: refs/heads/master
Commit: a348df538cfe65c32cc3ba2ecf9f56eb7c175522
Parents: 709e217
Author: Dongjoon Hyun <do...@apache.org>
Authored: Wed Oct 28 15:11:37 2015 +0900
Committer: Andrew Chung <af...@gmail.com>
Committed: Wed Oct 28 15:28:59 2015 -0700

----------------------------------------------------------------------
 .../org/apache/reef/wake/IdentifierParser.java  | 60 --------------------
 .../reef/wake/storage/FileHandlePool.java       | 36 ------------
 .../apache/reef/wake/storage/ReadRequest.java   | 55 ------------------
 .../apache/reef/wake/storage/ReadResponse.java  | 48 ----------------
 4 files changed, 199 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/a348df53/lang/java/reef-wake/wake/src/main/java/org/apache/reef/wake/IdentifierParser.java
----------------------------------------------------------------------
diff --git a/lang/java/reef-wake/wake/src/main/java/org/apache/reef/wake/IdentifierParser.java b/lang/java/reef-wake/wake/src/main/java/org/apache/reef/wake/IdentifierParser.java
deleted file mode 100644
index 9f23e37..0000000
--- a/lang/java/reef-wake/wake/src/main/java/org/apache/reef/wake/IdentifierParser.java
+++ /dev/null
@@ -1,60 +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.reef.wake;
-
-import org.apache.reef.tang.ExternalConstructor;
-import org.apache.reef.wake.impl.DefaultIdentifierFactory;
-import org.apache.reef.wake.remote.impl.SocketRemoteIdentifier;
-import org.apache.reef.wake.storage.FileIdentifier;
-
-import javax.inject.Inject;
-import java.util.Map;
-import java.util.concurrent.ConcurrentHashMap;
-
-/**
- * @deprecated in 0.13
- */
-
-@Deprecated
-public class IdentifierParser implements ExternalConstructor<Identifier> {
-  private static final IdentifierFactory FACTORY;
-
-  // TODO: Modify tang to allow this to use a factory pattern.
-  static {
-    final Map<String, Class<? extends Identifier>> map = new ConcurrentHashMap<>();
-
-    map.put("socket", SocketRemoteIdentifier.class);
-    map.put("file", FileIdentifier.class);
-
-    FACTORY = new DefaultIdentifierFactory(map);
-  }
-
-  private final Identifier id;
-
-  @Inject
-  IdentifierParser(final String s) {
-    id = FACTORY.getNewInstance(s);
-  }
-
-  @Override
-  public Identifier newInstance() {
-    return id;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/a348df53/lang/java/reef-wake/wake/src/main/java/org/apache/reef/wake/storage/FileHandlePool.java
----------------------------------------------------------------------
diff --git a/lang/java/reef-wake/wake/src/main/java/org/apache/reef/wake/storage/FileHandlePool.java b/lang/java/reef-wake/wake/src/main/java/org/apache/reef/wake/storage/FileHandlePool.java
deleted file mode 100644
index c9d6a5b..0000000
--- a/lang/java/reef-wake/wake/src/main/java/org/apache/reef/wake/storage/FileHandlePool.java
+++ /dev/null
@@ -1,36 +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.reef.wake.storage;
-
-import java.io.FileInputStream;
-
-/**
- * @deprecated in 0.13
- */
-
-@Deprecated
-public class FileHandlePool {
-  public FileInputStream get(final StorageIdentifier f) {
-    return null;
-  }
-
-  public void release(final StorageIdentifier f, final FileInputStream is) {
-
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/a348df53/lang/java/reef-wake/wake/src/main/java/org/apache/reef/wake/storage/ReadRequest.java
----------------------------------------------------------------------
diff --git a/lang/java/reef-wake/wake/src/main/java/org/apache/reef/wake/storage/ReadRequest.java b/lang/java/reef-wake/wake/src/main/java/org/apache/reef/wake/storage/ReadRequest.java
deleted file mode 100644
index 888d7a4..0000000
--- a/lang/java/reef-wake/wake/src/main/java/org/apache/reef/wake/storage/ReadRequest.java
+++ /dev/null
@@ -1,55 +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.reef.wake.storage;
-
-import org.apache.reef.wake.Identifiable;
-import org.apache.reef.wake.Identifier;
-
-/**
- * @deprecated in 0.13
- */
-
-@Deprecated
-public class ReadRequest implements Identifiable {
-  private final StorageIdentifier f;
-  private final long offset;
-  private final byte[] buf;
-  private final Identifier id;
-
-  public ReadRequest(final StorageIdentifier f, final long offset, final byte[] buf, final Identifier id) {
-    this.f = f;
-    this.offset = offset;
-    this.buf = buf;
-    this.id = id;
-  }
-
-  @Override
-  public Identifier getId() {
-    return id;
-  }
-  public StorageIdentifier getF() {
-    return f;
-  }
-  public long getOffset() {
-    return offset;
-  }
-  public byte[] getBuf() {
-    return buf;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/a348df53/lang/java/reef-wake/wake/src/main/java/org/apache/reef/wake/storage/ReadResponse.java
----------------------------------------------------------------------
diff --git a/lang/java/reef-wake/wake/src/main/java/org/apache/reef/wake/storage/ReadResponse.java b/lang/java/reef-wake/wake/src/main/java/org/apache/reef/wake/storage/ReadResponse.java
deleted file mode 100644
index cde7419..0000000
--- a/lang/java/reef-wake/wake/src/main/java/org/apache/reef/wake/storage/ReadResponse.java
+++ /dev/null
@@ -1,48 +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.reef.wake.storage;
-
-import org.apache.reef.wake.Identifier;
-
-/**
- * @deprecated in 0.13
- */
-
-@Deprecated
-public class ReadResponse {
-  private final byte[] buf;
-  private final int bytesRead;
-  private final Identifier reqId;
-
-  public ReadResponse(final byte[] buf, final int bytesRead, final Identifier reqId) {
-    this.buf = buf;
-    this.bytesRead = bytesRead;
-    this.reqId = reqId;
-  }
-
-/*  public byte[] getBuf() {
-    return buf;
-  }
-  public int getBytesRead() {
-    return bytesRead;
-  }
-  public Identifier getReqId() {
-    return reqId;
-  }*/
-}