You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@flink.apache.org by se...@apache.org on 2018/07/15 22:23:45 UTC

[3/6] flink git commit: [hotfix] [core] Remove unused class AbstractMultiFSDataInputStream

[hotfix] [core] Remove unused class AbstractMultiFSDataInputStream


Project: http://git-wip-us.apache.org/repos/asf/flink/repo
Commit: http://git-wip-us.apache.org/repos/asf/flink/commit/66e0a271
Tree: http://git-wip-us.apache.org/repos/asf/flink/tree/66e0a271
Diff: http://git-wip-us.apache.org/repos/asf/flink/diff/66e0a271

Branch: refs/heads/master
Commit: 66e0a271ad24277330f1de54db7798a2389a671a
Parents: f247598
Author: Stephan Ewen <se...@apache.org>
Authored: Fri Jun 29 19:27:58 2018 +0200
Committer: Stephan Ewen <se...@apache.org>
Committed: Sun Jul 15 23:18:56 2018 +0200

----------------------------------------------------------------------
 .../core/fs/AbstractMultiFSDataInputStream.java | 115 -------------------
 1 file changed, 115 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/flink/blob/66e0a271/flink-core/src/main/java/org/apache/flink/core/fs/AbstractMultiFSDataInputStream.java
----------------------------------------------------------------------
diff --git a/flink-core/src/main/java/org/apache/flink/core/fs/AbstractMultiFSDataInputStream.java b/flink-core/src/main/java/org/apache/flink/core/fs/AbstractMultiFSDataInputStream.java
deleted file mode 100644
index e01ac2e..0000000
--- a/flink-core/src/main/java/org/apache/flink/core/fs/AbstractMultiFSDataInputStream.java
+++ /dev/null
@@ -1,115 +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.core.fs;
-
-import org.apache.flink.annotation.Internal;
-import org.apache.flink.util.IOUtils;
-import org.apache.flink.util.Preconditions;
-
-import java.io.EOFException;
-import java.io.IOException;
-
-/**
- * Abstract base class for wrappers over multiple {@link FSDataInputStream}, which gives a contiguous view on all inner
- * streams and makes them look like a single stream, in which we can read, seek, etc.
- */
-@Internal
-public abstract class AbstractMultiFSDataInputStream extends FSDataInputStream {
-
-	/** Inner stream for the currently accessed segment of the virtual global stream. */
-	protected FSDataInputStream delegate;
-
-	/** Position in the virtual global stream. */
-	protected long totalPos;
-
-	/** Total available bytes in the virtual global stream. */
-	protected long totalAvailable;
-
-	public AbstractMultiFSDataInputStream() {
-		this.totalPos = 0L;
-	}
-
-	@Override
-	public void seek(long desired) throws IOException {
-
-		if (desired == totalPos) {
-			return;
-		}
-
-		Preconditions.checkArgument(desired >= 0L);
-
-		if (desired > totalAvailable) {
-			throw new EOFException();
-		}
-
-		IOUtils.closeQuietly(delegate);
-		delegate = getSeekedStreamForOffset(desired);
-
-		this.totalPos = desired;
-	}
-
-	@Override
-	public long getPos() throws IOException {
-		return totalPos;
-	}
-
-	@Override
-	public int read() throws IOException {
-
-		if (null == delegate) {
-			return -1;
-		}
-
-		int val = delegate.read();
-
-		if (-1 == val) {
-			IOUtils.closeQuietly(delegate);
-			if (totalPos < totalAvailable) {
-				delegate = getSeekedStreamForOffset(totalPos);
-			} else {
-				delegate = null;
-			}
-			return read();
-		}
-
-		++totalPos;
-		return val;
-	}
-
-	@Override
-	public void close() throws IOException {
-		IOUtils.closeQuietly(delegate);
-	}
-
-	@Override
-	public long skip(long n) throws IOException {
-		seek(totalPos + n);
-		return n;
-	}
-
-	/**
-	 * Delivers a the right stream for the given global stream offset. The returned stream is already seeked to the
-	 * right local offset that correctly reflects the global offset.
-	 *
-	 * @param globalStreamOffset the global offset to which we seek
-	 * @return a sub-stream, seeked to the correct local offset w.r.t. the global offset.
-	 * @throws IOException
-	 */
-	protected abstract FSDataInputStream getSeekedStreamForOffset(long globalStreamOffset) throws IOException;
-}