Skip to content

Commit

Permalink
forgot a couple of fixes
Browse files Browse the repository at this point in the history
  • Loading branch information
Joseph Batchik committed Jul 15, 2015
1 parent c5fe794 commit fa9298b
Show file tree
Hide file tree
Showing 2 changed files with 2 additions and 4 deletions.
Original file line number Diff line number Diff line change
Expand Up @@ -67,7 +67,6 @@ private[serializer] class GenericAvroSerializer(schemas: Map[Long, String])
bos.toByteArray
})


/**
* Decompresses the schema into the actual in-memory object. Keeps an internal cache of already
* seen values so to limit the number of times that decompression has to be done.
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -21,10 +21,10 @@ import java.io.{EOFException, IOException, InputStream, OutputStream}
import java.nio.ByteBuffer
import javax.annotation.Nullable

import org.apache.avro.generic.{GenericData, GenericRecord}

import scala.reflect.ClassTag

import org.apache.avro.generic.{GenericData, GenericRecord}

import com.esotericsoftware.kryo.{Kryo, KryoException}
import com.esotericsoftware.kryo.io.{Input => KryoInput, Output => KryoOutput}
import com.esotericsoftware.kryo.serializers.{JavaSerializer => KryoJavaSerializer}
Expand All @@ -34,7 +34,6 @@ import org.roaringbitmap.{ArrayContainer, BitmapContainer, RoaringArray, Roaring
import org.apache.spark._
import org.apache.spark.api.python.PythonBroadcast
import org.apache.spark.broadcast.HttpBroadcast
import org.apache.spark.io.CompressionCodec
import org.apache.spark.network.nio.{GetBlock, GotBlock, PutBlock}
import org.apache.spark.network.util.ByteUnit
import org.apache.spark.scheduler.{CompressedMapStatus, HighlyCompressedMapStatus}
Expand Down

0 comments on commit fa9298b

Please sign in to comment.