You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hbase.apache.org by ap...@apache.org on 2021/10/22 01:43:17 UTC

[hbase] branch master updated: Revert "HBASE-26353 Support loadable dictionaries in hbase-compression-zstd (#3748)"

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

apurtell pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/hbase.git


The following commit(s) were added to refs/heads/master by this push:
     new e0813e5  Revert "HBASE-26353 Support loadable dictionaries in hbase-compression-zstd (#3748)"
e0813e5 is described below

commit e0813e540242acec96fa041111c73dc9f9f64bc0
Author: Andrew Purtell <ap...@apache.org>
AuthorDate: Thu Oct 21 18:41:26 2021 -0700

    Revert "HBASE-26353 Support loadable dictionaries in hbase-compression-zstd (#3748)"
    
    This reverts commit bfa45841251e3224e3fbb07599ae5dd6791b2846.
    
    This is not ready yet. There are some code paths remaining where store
    configuration (CompoundConfiguration) is not passed into the block decoding
    context. Found with additional integration tests.
---
 .../hadoop/hbase/io/compress/CompressionUtil.java  |   2 -
 .../hadoop/hbase/io/compress/DictionaryCache.java  | 164 ---------------------
 .../hbase/io/compress/CompressionTestBase.java     |  69 +++------
 .../hadoop/hbase/io/compress/zstd/ZstdCodec.java   |  15 +-
 .../hbase/io/compress/zstd/ZstdCompressor.java     |  23 +--
 .../hbase/io/compress/zstd/ZstdDecompressor.java   |  24 +--
 .../hbase/io/compress/zstd/TestZstdCodec.java      |  68 +--------
 .../src/test/resources/zstd.test.data              | Bin 1024000 -> 0 bytes
 .../src/test/resources/zstd.test.dict              | Bin 112640 -> 0 bytes
 9 files changed, 34 insertions(+), 331 deletions(-)

diff --git a/hbase-common/src/main/java/org/apache/hadoop/hbase/io/compress/CompressionUtil.java b/hbase-common/src/main/java/org/apache/hadoop/hbase/io/compress/CompressionUtil.java
index 1ebf124..becff76 100644
--- a/hbase-common/src/main/java/org/apache/hadoop/hbase/io/compress/CompressionUtil.java
+++ b/hbase-common/src/main/java/org/apache/hadoop/hbase/io/compress/CompressionUtil.java
@@ -21,8 +21,6 @@ import org.apache.yetus.audience.InterfaceAudience;
 @InterfaceAudience.Private
 public class CompressionUtil {
 
-  private CompressionUtil() { }
-
   /**
    * Round up to the next power of two, unless the value would become negative (ints
    * are signed), in which case just return Integer.MAX_VALUE.
diff --git a/hbase-common/src/main/java/org/apache/hadoop/hbase/io/compress/DictionaryCache.java b/hbase-common/src/main/java/org/apache/hadoop/hbase/io/compress/DictionaryCache.java
deleted file mode 100644
index 5e19e93..0000000
--- a/hbase-common/src/main/java/org/apache/hadoop/hbase/io/compress/DictionaryCache.java
+++ /dev/null
@@ -1,164 +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.hadoop.hbase.io.compress;
-
-import java.io.ByteArrayOutputStream;
-import java.io.FileNotFoundException;
-import java.io.IOException;
-import java.io.InputStream;
-import java.util.concurrent.ExecutionException;
-import java.util.concurrent.TimeUnit;
-import org.apache.hadoop.conf.Configuration;
-import org.apache.hadoop.fs.FSDataInputStream;
-import org.apache.hadoop.fs.FileStatus;
-import org.apache.hadoop.fs.FileSystem;
-import org.apache.hadoop.fs.Path;
-import org.apache.yetus.audience.InterfaceAudience;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-import org.apache.hbase.thirdparty.com.google.common.cache.CacheBuilder;
-import org.apache.hbase.thirdparty.com.google.common.cache.CacheLoader;
-import org.apache.hbase.thirdparty.com.google.common.cache.LoadingCache;
-
-/**
- * A utility class for managing compressor/decompressor dictionary loading and caching of load
- * results. Useful for any codec that can support changing dictionaries at runtime,
- * such as ZStandard.
- */
-@InterfaceAudience.Private
-public class DictionaryCache {
-
-  public static final String DICTIONARY_MAX_SIZE_KEY = "hbase.io.compress.dictionary.max.size";
-  public static final int DEFAULT_DICTIONARY_MAX_SIZE = 10 * 1024 * 1024;
-  public static final String RESOURCE_SCHEME = "resource://";
-
-  private static final Logger LOG = LoggerFactory.getLogger(DictionaryCache.class);
-  private static volatile LoadingCache<String, byte[]> CACHE;
-
-  private DictionaryCache() { }
-
-  /**
-   * Load a dictionary or return a previously cached load.
-   * @param conf configuration
-   * @param path the hadoop Path where the dictionary is located, as a String
-   * @return the dictionary bytes if successful, null otherwise
-   */
-  public static byte[] getDictionary(final Configuration conf, final String path)
-      throws IOException {
-    if (path == null || path.isEmpty()) {
-      return null;
-    }
-    // Create the dictionary loading cache if we haven't already
-    if (CACHE == null) {
-      synchronized (DictionaryCache.class) {
-        if (CACHE == null) {
-          final int maxSize = conf.getInt(DICTIONARY_MAX_SIZE_KEY, DEFAULT_DICTIONARY_MAX_SIZE);
-          CACHE = CacheBuilder.newBuilder()
-            .maximumSize(100)
-            .expireAfterAccess(10, TimeUnit.MINUTES)
-            .build(
-              new CacheLoader<String, byte[]>() {
-                public byte[] load(String s) throws Exception {
-                  byte[] bytes;
-                  if (path.startsWith(RESOURCE_SCHEME)) {
-                    bytes = loadFromResource(conf, path, maxSize);
-                  } else {
-                    bytes = loadFromHadoopFs(conf, path, maxSize);
-                  }
-                  LOG.info("Loaded dictionary from {} (size {})", s, bytes.length);
-                  return bytes;
-                }
-              });
-        }
-      }
-    }
-
-    // Get or load the dictionary for the given path
-    try {
-      return CACHE.get(path);
-    } catch (ExecutionException e) {
-      throw new RuntimeException(e);
-    }
-  }
-
-  // Visible for testing
-  public static byte[] loadFromResource(final Configuration conf, final String s,
-      final int maxSize) throws IOException {
-    if (!s.startsWith(RESOURCE_SCHEME)) {
-      throw new IllegalArgumentException("Path does not start with " + RESOURCE_SCHEME);
-    }
-    final String path = s.substring(RESOURCE_SCHEME.length(), s.length());
-    final InputStream in = DictionaryCache.class.getClassLoader().getResourceAsStream(path);
-    if (in == null) {
-      throw new FileNotFoundException("Resource " + path + " not found");
-    }
-    final ByteArrayOutputStream baos = new ByteArrayOutputStream();
-    final byte[] buffer = new byte[8192];
-    try {
-      int n, len = 0;
-      do {
-        n = in.read(buffer);
-        if (n > 0) {
-          len += n;
-          if (len > maxSize) {
-            throw new IllegalArgumentException("Dictionary " + s + " is too large" +
-              ", limit=" + maxSize);
-          }
-          baos.write(buffer, 0, n);
-        }
-      } while (n > 0);
-    } finally {
-      in.close();
-    }
-    return baos.toByteArray();
-  }
-
-  private static byte[] loadFromHadoopFs(final Configuration conf, final String s,
-      final int maxSize) throws IOException {
-    final Path path = new Path(s);
-    final FileSystem fs = FileSystem.get(path.toUri(), conf);
-    final FileStatus stat = fs.getFileStatus(path);
-    if (!stat.isFile()) {
-      throw new IllegalArgumentException(s + " is not a file");
-    }
-    if (stat.getLen() > maxSize) {
-      throw new IllegalArgumentException("Dictionary " + s + " is too large" +
-        ", size=" + stat.getLen() + ", limit=" + maxSize);
-    }
-    final ByteArrayOutputStream baos = new ByteArrayOutputStream();
-    final byte[] buffer = new byte[8192];
-    try (final FSDataInputStream in = fs.open(path)) {
-      int n;
-      do {
-        n = in.read(buffer);
-        if (n > 0) {
-          baos.write(buffer, 0, n);
-        }
-      } while (n > 0);
-    }
-    return baos.toByteArray();
-  }
-
-  // Visible for testing
-  public static boolean contains(String dictionaryPath) {
-    if (CACHE != null) {
-      return CACHE.asMap().containsKey(dictionaryPath);
-    }
-    return false;
-  }
-
-}
diff --git a/hbase-common/src/test/java/org/apache/hadoop/hbase/io/compress/CompressionTestBase.java b/hbase-common/src/test/java/org/apache/hadoop/hbase/io/compress/CompressionTestBase.java
index e259e1b..616bf0b 100644
--- a/hbase-common/src/test/java/org/apache/hadoop/hbase/io/compress/CompressionTestBase.java
+++ b/hbase-common/src/test/java/org/apache/hadoop/hbase/io/compress/CompressionTestBase.java
@@ -17,10 +17,12 @@
 package org.apache.hadoop.hbase.io.compress;
 
 import static org.junit.Assert.assertTrue;
+
 import java.io.ByteArrayInputStream;
 import java.io.ByteArrayOutputStream;
 import java.util.Arrays;
 import java.util.Random;
+
 import org.apache.hadoop.conf.Configurable;
 import org.apache.hadoop.hbase.util.Bytes;
 import org.apache.hadoop.hbase.util.EnvironmentEdgeManager;
@@ -29,8 +31,6 @@ import org.apache.hadoop.io.IOUtils;
 import org.apache.hadoop.io.compress.CompressionCodec;
 import org.apache.hadoop.io.compress.CompressionInputStream;
 import org.apache.hadoop.io.compress.CompressionOutputStream;
-import org.apache.hadoop.io.compress.Compressor;
-import org.apache.hadoop.io.compress.Decompressor;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
@@ -39,11 +39,11 @@ public class CompressionTestBase {
 
   protected static final Logger LOG = LoggerFactory.getLogger(CompressionTestBase.class);
 
-  protected static final int LARGE_SIZE = 10 * 1024 * 1024;
-  protected static final int VERY_LARGE_SIZE = 100 * 1024 * 1024;
-  protected static final int BLOCK_SIZE = 4096;
+  static final int LARGE_SIZE = 10 * 1024 * 1024;
+  static final int VERY_LARGE_SIZE = 100 * 1024 * 1024;
+  static final int BLOCK_SIZE = 4096;
 
-  protected static final byte[] SMALL_INPUT;
+  static final byte[] SMALL_INPUT;
   static {
     // 1, 1, 2, 3, 5, 8, 13, 21, 34, 55, 89, 144, 233, 377, 610, 987, 1597
     SMALL_INPUT = new byte[1+1+2+3+5+8+13+21+34+55+89+144+233+377+610+987+1597];
@@ -67,21 +67,15 @@ public class CompressionTestBase {
     Arrays.fill(SMALL_INPUT, off, (off+=1597), (byte)'Q');
   }
 
-  protected void codecTest(final CompressionCodec codec, final byte[][] input) throws Exception {
-    codecTest(codec, input, null);
-  }
-
-  protected void codecTest(final CompressionCodec codec, final byte[][] input,
-      final Integer expectedCompressedSize) throws Exception {
+  protected void codecTest(final CompressionCodec codec, final byte[][] input)
+      throws Exception {
     // We do this in Compression.java
     ((Configurable)codec).getConf().setInt("io.file.buffer.size", 32 * 1024);
     // Compress
-    long start = EnvironmentEdgeManager.currentTime();
-    Compressor compressor = codec.createCompressor();
-    compressor.reinit(((Configurable)codec).getConf());
     ByteArrayOutputStream baos = new ByteArrayOutputStream();
-    CompressionOutputStream out = codec.createOutputStream(baos, compressor);
+    CompressionOutputStream out = codec.createOutputStream(baos);
     int inLen = 0;
+    long start = EnvironmentEdgeManager.currentTime();
     for (int i = 0; i < input.length; i++) {
       out.write(input[i]);
       inLen += input[i].length;
@@ -91,18 +85,9 @@ public class CompressionTestBase {
     final byte[] compressed = baos.toByteArray();
     LOG.info("{} compressed {} bytes to {} bytes in {} ms", codec.getClass().getSimpleName(),
       inLen, compressed.length, end - start);
-    if (expectedCompressedSize != null) {
-      assertTrue("Expected compressed size does not match: (expected=" + expectedCompressedSize +
-        ", actual=" + compressed.length + ")", expectedCompressedSize == compressed.length);
-    }
     // Decompress
     final byte[] plain = new byte[inLen];
-    Decompressor decompressor = codec.createDecompressor();
-    if (decompressor instanceof CanReinit) {
-      ((CanReinit)decompressor).reinit(((Configurable)codec).getConf());
-    }
-    CompressionInputStream in = codec.createInputStream(new ByteArrayInputStream(compressed),
-      decompressor);
+    CompressionInputStream in = codec.createInputStream(new ByteArrayInputStream(compressed));
     start = EnvironmentEdgeManager.currentTime();
     IOUtils.readFully(in, plain, 0, plain.length);
     in.close();
@@ -128,37 +113,29 @@ public class CompressionTestBase {
   /**
    * Test with a large input (1MB) divided into blocks of 4KB.
    */
-  protected void codecLargeTest(final CompressionCodec codec, final double sigma)
-      throws Exception {
-    RandomDistribution.DiscreteRNG rng =
+  protected void codecLargeTest(final CompressionCodec codec, final double sigma) throws Exception {
+    RandomDistribution.DiscreteRNG zipf =
       new RandomDistribution.Zipf(new Random(), 0, Byte.MAX_VALUE, sigma);
     final byte[][] input = new byte[LARGE_SIZE/BLOCK_SIZE][BLOCK_SIZE];
-    fill(rng, input);
+    for (int i = 0; i < input.length; i++) {
+      for (int j = 0; j < input[i].length; j++) {
+        input[i][j] = (byte)zipf.nextInt();
+      }
+    }
     codecTest(codec, input);
   }
 
   /**
    * Test with a very large input (100MB) as a single input buffer.
    */
-  protected void codecVeryLargeTest(final CompressionCodec codec, final double sigma)
-      throws Exception {
-    RandomDistribution.DiscreteRNG rng =
+  protected void codecVeryLargeTest(final CompressionCodec codec, final double sigma) throws Exception {
+    RandomDistribution.DiscreteRNG zipf =
         new RandomDistribution.Zipf(new Random(), 0, Byte.MAX_VALUE, sigma);
     final byte[][] input = new byte[1][VERY_LARGE_SIZE];
-    fill(rng, input);
-    codecTest(codec, input);
-  }
-
-  protected static void fill(RandomDistribution.DiscreteRNG rng, byte[][] input) {
-    for (int i = 0; i < input.length; i++) {
-      fill(rng, input[i]);
-    }
-  }
-
-  protected static void fill(RandomDistribution.DiscreteRNG rng, byte[] input) {
-    for (int i = 0; i < input.length; i++) {
-      input[i] = (byte) rng.nextInt();
+    for (int i = 0; i < VERY_LARGE_SIZE; i++) {
+      input[0][i] = (byte)zipf.nextInt();
     }
+    codecTest(codec, input);
   }
 
 }
diff --git a/hbase-compression/hbase-compression-zstd/src/main/java/org/apache/hadoop/hbase/io/compress/zstd/ZstdCodec.java b/hbase-compression/hbase-compression-zstd/src/main/java/org/apache/hadoop/hbase/io/compress/zstd/ZstdCodec.java
index 8f8dae1..fc5f445 100644
--- a/hbase-compression/hbase-compression-zstd/src/main/java/org/apache/hadoop/hbase/io/compress/zstd/ZstdCodec.java
+++ b/hbase-compression/hbase-compression-zstd/src/main/java/org/apache/hadoop/hbase/io/compress/zstd/ZstdCodec.java
@@ -22,7 +22,6 @@ import java.io.OutputStream;
 import org.apache.hadoop.conf.Configurable;
 import org.apache.hadoop.conf.Configuration;
 import org.apache.hadoop.fs.CommonConfigurationKeys;
-import org.apache.hadoop.hbase.io.compress.DictionaryCache;
 import org.apache.hadoop.io.compress.BlockCompressorStream;
 import org.apache.hadoop.io.compress.BlockDecompressorStream;
 import org.apache.hadoop.io.compress.CompressionCodec;
@@ -42,7 +41,6 @@ public class ZstdCodec implements Configurable, CompressionCodec {
 
   public static final String ZSTD_LEVEL_KEY = "hbase.io.compress.zstd.level";
   public static final String ZSTD_BUFFER_SIZE_KEY = "hbase.io.compress.zstd.buffersize";
-  public static final String ZSTD_DICTIONARY_KEY = "hbase.io.compress.zstd.dictionary";
 
   private Configuration conf;
 
@@ -62,12 +60,12 @@ public class ZstdCodec implements Configurable, CompressionCodec {
 
   @Override
   public Compressor createCompressor() {
-    return new ZstdCompressor(getLevel(conf), getBufferSize(conf), getDictionary(conf));
+    return new ZstdCompressor(getLevel(conf), getBufferSize(conf));
   }
 
   @Override
   public Decompressor createDecompressor() {
-    return new ZstdDecompressor(getBufferSize(conf), getDictionary(conf));
+    return new ZstdDecompressor(getBufferSize(conf));
   }
 
   @Override
@@ -125,13 +123,4 @@ public class ZstdCodec implements Configurable, CompressionCodec {
     return size > 0 ? size : 256 * 1024; // Don't change this default
   }
 
-  static byte[] getDictionary(final Configuration conf) {
-    String path = conf.get(ZSTD_DICTIONARY_KEY);
-    try {
-      return DictionaryCache.getDictionary(conf, path);
-    } catch (IOException e) {
-      throw new RuntimeException("Unable to load dictionary at " + path, e);
-    }
-  }
-
 }
diff --git a/hbase-compression/hbase-compression-zstd/src/main/java/org/apache/hadoop/hbase/io/compress/zstd/ZstdCompressor.java b/hbase-compression/hbase-compression-zstd/src/main/java/org/apache/hadoop/hbase/io/compress/zstd/ZstdCompressor.java
index 1be6131..b9d9da1 100644
--- a/hbase-compression/hbase-compression-zstd/src/main/java/org/apache/hadoop/hbase/io/compress/zstd/ZstdCompressor.java
+++ b/hbase-compression/hbase-compression-zstd/src/main/java/org/apache/hadoop/hbase/io/compress/zstd/ZstdCompressor.java
@@ -26,7 +26,6 @@ import org.apache.yetus.audience.InterfaceAudience;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 import com.github.luben.zstd.Zstd;
-import com.github.luben.zstd.ZstdDictCompress;
 
 /**
  * Hadoop compressor glue for zstd-jni.
@@ -39,21 +38,13 @@ public class ZstdCompressor implements CanReinit, Compressor {
   protected ByteBuffer inBuf, outBuf;
   protected boolean finish, finished;
   protected long bytesRead, bytesWritten;
-  protected ZstdDictCompress dict;
 
-  ZstdCompressor(final int level, final int bufferSize, final byte[] dictionary) {
+  ZstdCompressor(final int level, final int bufferSize) {
     this.level = level;
     this.bufferSize = bufferSize;
     this.inBuf = ByteBuffer.allocateDirect(bufferSize);
     this.outBuf = ByteBuffer.allocateDirect(bufferSize);
     this.outBuf.position(bufferSize);
-    if (dictionary != null) {
-      this.dict = new ZstdDictCompress(dictionary, level);
-    }
-  }
-
-  ZstdCompressor(final int level, final int bufferSize) {
-    this(level, bufferSize, null);
   }
 
   @Override
@@ -81,12 +72,7 @@ public class ZstdCompressor implements CanReinit, Compressor {
         } else {
           outBuf.clear();
         }
-        int written;
-        if (dict != null) {
-          written = Zstd.compress(outBuf, inBuf, dict);
-        } else {
-          written = Zstd.compress(outBuf, inBuf, level);
-        }
+        int written = Zstd.compress(outBuf, inBuf, level);
         bytesWritten += written;
         inBuf.clear();
         LOG.trace("compress: compressed {} -> {} (level {})", uncompressed, written, level);
@@ -145,11 +131,6 @@ public class ZstdCompressor implements CanReinit, Compressor {
     if (conf != null) {
       // Level might have changed
       level = ZstdCodec.getLevel(conf);
-      // Dictionary may have changed
-      byte[] b = ZstdCodec.getDictionary(conf);
-      if (b != null) {
-        dict = new ZstdDictCompress(b, level);
-      }
       // Buffer size might have changed
       int newBufferSize = ZstdCodec.getBufferSize(conf);
       if (bufferSize != newBufferSize) {
diff --git a/hbase-compression/hbase-compression-zstd/src/main/java/org/apache/hadoop/hbase/io/compress/zstd/ZstdDecompressor.java b/hbase-compression/hbase-compression-zstd/src/main/java/org/apache/hadoop/hbase/io/compress/zstd/ZstdDecompressor.java
index 473eac7..a3d77f5 100644
--- a/hbase-compression/hbase-compression-zstd/src/main/java/org/apache/hadoop/hbase/io/compress/zstd/ZstdDecompressor.java
+++ b/hbase-compression/hbase-compression-zstd/src/main/java/org/apache/hadoop/hbase/io/compress/zstd/ZstdDecompressor.java
@@ -26,7 +26,6 @@ import org.apache.yetus.audience.InterfaceAudience;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 import com.github.luben.zstd.Zstd;
-import com.github.luben.zstd.ZstdDictDecompress;
 
 /**
  * Hadoop decompressor glue for zstd-java.
@@ -39,20 +38,12 @@ public class ZstdDecompressor implements CanReinit, Decompressor {
   protected int bufferSize;
   protected int inLen;
   protected boolean finished;
-  protected ZstdDictDecompress dict;
 
-  ZstdDecompressor(final int bufferSize, final byte[] dictionary) {
+  ZstdDecompressor(final int bufferSize) {
     this.bufferSize = bufferSize;
     this.inBuf = ByteBuffer.allocateDirect(bufferSize);
     this.outBuf = ByteBuffer.allocateDirect(bufferSize);
     this.outBuf.position(bufferSize);
-    if (dictionary != null) {
-      this.dict = new ZstdDictDecompress(dictionary);
-    }
-  }
-
-  ZstdDecompressor(final int bufferSize) {
-    this(bufferSize, null);
   }
 
   @Override
@@ -69,11 +60,7 @@ public class ZstdDecompressor implements CanReinit, Decompressor {
       inLen -= remaining;
       outBuf.clear();
       int written;
-      if (dict != null) {
-        written = Zstd.decompress(outBuf, inBuf, dict);
-      } else {
-        written = Zstd.decompress(outBuf, inBuf);
-      }
+      written = Zstd.decompress(outBuf, inBuf);
       inBuf.clear();
       LOG.trace("decompress: decompressed {} -> {}", remaining, written);
       outBuf.flip();
@@ -130,7 +117,7 @@ public class ZstdDecompressor implements CanReinit, Decompressor {
   @Override
   public void setDictionary(final byte[] b, final int off, final int len) {
     LOG.trace("setDictionary: off={} len={}", off, len);
-    this.dict = new ZstdDictDecompress(b, off, len);
+    throw new UnsupportedOperationException("setDictionary not supported");
   }
 
   @Override
@@ -156,11 +143,6 @@ public class ZstdDecompressor implements CanReinit, Decompressor {
   public void reinit(final Configuration conf) {
     LOG.trace("reinit");
     if (conf != null) {
-      // Dictionary may have changed
-      byte[] b = ZstdCodec.getDictionary(conf);
-      if (b != null) {
-        dict = new ZstdDictDecompress(b);
-      }
       // Buffer size might have changed
       int newBufferSize = ZstdCodec.getBufferSize(conf);
       if (bufferSize != newBufferSize) {
diff --git a/hbase-compression/hbase-compression-zstd/src/test/java/org/apache/hadoop/hbase/io/compress/zstd/TestZstdCodec.java b/hbase-compression/hbase-compression-zstd/src/test/java/org/apache/hadoop/hbase/io/compress/zstd/TestZstdCodec.java
index 7745c9a..6bcb2aa 100644
--- a/hbase-compression/hbase-compression-zstd/src/test/java/org/apache/hadoop/hbase/io/compress/zstd/TestZstdCodec.java
+++ b/hbase-compression/hbase-compression-zstd/src/test/java/org/apache/hadoop/hbase/io/compress/zstd/TestZstdCodec.java
@@ -16,20 +16,11 @@
  */
 package org.apache.hadoop.hbase.io.compress.zstd;
 
-import static org.junit.Assert.assertNotNull;
-import static org.junit.Assert.assertTrue;
-import java.io.File;
-import java.io.FileOutputStream;
-import java.io.IOException;
-import java.util.Random;
 import org.apache.hadoop.conf.Configuration;
 import org.apache.hadoop.fs.CommonConfigurationKeys;
 import org.apache.hadoop.hbase.HBaseClassTestRule;
-import org.apache.hadoop.hbase.HBaseConfiguration;
 import org.apache.hadoop.hbase.io.compress.CompressionTestBase;
-import org.apache.hadoop.hbase.io.compress.DictionaryCache;
 import org.apache.hadoop.hbase.testclassification.SmallTests;
-import org.apache.hadoop.hbase.util.RandomDistribution;
 import org.junit.ClassRule;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
@@ -42,20 +33,20 @@ public class TestZstdCodec extends CompressionTestBase {
       HBaseClassTestRule.forClass(TestZstdCodec.class);
 
   @Test
-  public void testZstdCodecSmall() throws Exception {
+  public void testzstdCodecSmall() throws Exception {
     codecSmallTest(new ZstdCodec());
   }
 
   @Test
-  public void testZstdCodecLarge() throws Exception {
+  public void testzstdCodecLarge() throws Exception {
     codecLargeTest(new ZstdCodec(), 1.1); // poor compressability
     codecLargeTest(new ZstdCodec(),   2);
     codecLargeTest(new ZstdCodec(),  10); // very high compressability
   }
 
   @Test
-  public void testZstdCodecVeryLarge() throws Exception {
-    Configuration conf = HBaseConfiguration.create();
+  public void testzstdCodecVeryLarge() throws Exception {
+    Configuration conf = new Configuration();
     // ZStandard levels range from 1 to 22.
     // Level 22 might take up to a minute to complete. 3 is the Hadoop default, and will be fast.
     conf.setInt(CommonConfigurationKeys.IO_COMPRESSION_CODEC_ZSTD_LEVEL_KEY, 3);
@@ -64,55 +55,4 @@ public class TestZstdCodec extends CompressionTestBase {
     codecVeryLargeTest(codec, 3); // like text
   }
 
-  @Test
-  public void testZstdCodecWithDictionary() throws Exception {
-    // zstd.test.data compressed with zstd.test.dict at level 3 will produce a result of
-    // 365533 bytes
-    final int expectedCompressedSize = 365533;
-    Configuration conf = HBaseConfiguration.create();
-    conf.setInt(CommonConfigurationKeys.IO_COMPRESSION_CODEC_ZSTD_LEVEL_KEY, 3);
-    // Configure for dictionary available in test resources
-    final String dictionaryPath = DictionaryCache.RESOURCE_SCHEME + "zstd.test.dict";
-    conf.set(ZstdCodec.ZSTD_DICTIONARY_KEY, dictionaryPath);
-    // Load test data from test resources
-    // This will throw an IOException if the test data cannot be loaded
-    final byte[] testData = DictionaryCache.loadFromResource(conf,
-      DictionaryCache.RESOURCE_SCHEME + "zstd.test.data", /* maxSize */ 1024*1024);
-    assertNotNull("Failed to load test data", testData);
-    // Run the test
-    // This will throw an IOException of some kind if there is a problem loading or using the
-    // dictionary.
-    ZstdCodec codec = new ZstdCodec();
-    codec.setConf(conf);
-    codecTest(codec, new byte[][] { testData }, expectedCompressedSize);
-    // Assert that the dictionary was actually loaded
-    assertTrue("Dictionary was not loaded by codec", DictionaryCache.contains(dictionaryPath));
-  }
-
-  //
-  // For generating the test data in src/test/resources/
-  //
-
-  public static void main(String[] args) throws IOException {
-    // Write 1000 1k blocks for training to the specified file
-    // Train with:
-    //   zstd --train-fastcover=k=32,b=8 -B1024 -o <dictionary_file> <input_file>
-    if (args.length < 1) {
-      System.err.println("Usage: TestZstdCodec <outFile>");
-      System.exit(-1);
-    }
-    final RandomDistribution.DiscreteRNG rng =
-      new RandomDistribution.Zipf(new Random(), 0, Byte.MAX_VALUE, 2);
-    final File outFile = new File(args[0]);
-    final byte[] buffer = new byte[1024];
-    System.out.println("Generating " + outFile);
-    try (FileOutputStream os = new FileOutputStream(outFile)) {
-      for (int i = 0; i < 1000; i++) {
-        fill(rng, buffer);
-        os.write(buffer);
-      }
-    }
-    System.out.println("Done");
-  }
-
 }
diff --git a/hbase-compression/hbase-compression-zstd/src/test/resources/zstd.test.data b/hbase-compression/hbase-compression-zstd/src/test/resources/zstd.test.data
deleted file mode 100644
index a497af5..0000000
Binary files a/hbase-compression/hbase-compression-zstd/src/test/resources/zstd.test.data and /dev/null differ
diff --git a/hbase-compression/hbase-compression-zstd/src/test/resources/zstd.test.dict b/hbase-compression/hbase-compression-zstd/src/test/resources/zstd.test.dict
deleted file mode 100644
index e5b79d2..0000000
Binary files a/hbase-compression/hbase-compression-zstd/src/test/resources/zstd.test.dict and /dev/null differ