blob: b3934edcae82a2403bfdcd23f944a06e4708888d [file] [log] [blame]
/**
* 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.crunch.scrunch.spark
import java.io._
import java.nio.ByteBuffer
import java.util
import org.apache.spark.serializer.{Serializer, DeserializationStream, SerializationStream, SerializerInstance}
import scala.reflect.ClassTag
import org.apache.spark.SparkConf
private[spark] class JavaSerializationStream(out: OutputStream, counterReset: Int)
extends SerializationStream {
private val objOut = new ObjectOutputStream(out)
private var counter = 0
/**
* Calling reset to avoid memory leak:
* http://stackoverflow.com/questions/1281549/memory-leak-traps-in-the-java-standard-api
* But only call it every 100th time to avoid bloated serialization streams (when
* the stream 'resets' object class descriptions have to be re-written)
*/
def writeObject[T: ClassTag](t: T): SerializationStream = {
objOut.writeObject(t)
counter += 1
if (counterReset > 0 && counter >= counterReset) {
objOut.reset()
counter = 0
}
this
}
def flush() { objOut.flush() }
def close() { objOut.close() }
}
private[spark] class JavaDeserializationStream(in: InputStream, loader: ClassLoader,
primitiveMapping: util.HashMap[String, Class[_]])
extends DeserializationStream {
private val objIn = new ObjectInputStream(in) {
override def resolveClass(desc: ObjectStreamClass): Class[_] = {
val name = desc.getName
if (primitiveMapping.containsKey(name)) {
return primitiveMapping.get(name)
}
Class.forName(desc.getName, false, loader)
}
}
def readObject[T: ClassTag](): T = objIn.readObject().asInstanceOf[T]
def close() { objIn.close() }
}
private[spark] class JavaSerializerInstance(counterReset: Int, defaultClassLoader: ClassLoader,
primitiveMappings: util.HashMap[String, Class[_]])
extends SerializerInstance {
override def serialize[T: ClassTag](t: T): ByteBuffer = {
val bos = new ByteArrayOutputStream()
val out = serializeStream(bos)
out.writeObject(t)
out.close()
ByteBuffer.wrap(bos.toByteArray)
}
override def deserialize[T: ClassTag](bytes: ByteBuffer): T = {
val bis = new ByteBufferInputStream(bytes)
val in = deserializeStream(bis)
in.readObject()
}
override def deserialize[T: ClassTag](bytes: ByteBuffer, loader: ClassLoader): T = {
val bis = new ByteBufferInputStream(bytes)
val in = deserializeStream(bis, loader)
in.readObject()
}
override def serializeStream(s: OutputStream): SerializationStream = {
new JavaSerializationStream(s, counterReset)
}
override def deserializeStream(s: InputStream): DeserializationStream = {
new JavaDeserializationStream(s, defaultClassLoader, primitiveMappings)
}
def deserializeStream(s: InputStream, loader: ClassLoader): DeserializationStream = {
new JavaDeserializationStream(s, loader, primitiveMappings)
}
}
class ScrunchSerializer(conf: SparkConf) extends Serializer with Externalizable {
private var counterReset = conf.getInt("spark.serializer.objectStreamReset", 100)
override def newInstance(): SerializerInstance = {
val classLoader = defaultClassLoader.getOrElse(Thread.currentThread.getContextClassLoader)
val classes = Array[Class[_]](classOf[Byte], classOf[Char], classOf[Short], classOf[Int],
classOf[Long], classOf[Float], classOf[Double], classOf[Boolean])
val mapping = new util.HashMap[String, Class[_]]()
classes.foreach(cls => {mapping.put(cls.getCanonicalName, cls)})
new JavaSerializerInstance(counterReset, classLoader, mapping)
}
override def writeExternal(out: ObjectOutput): Unit = {
out.writeInt(counterReset)
}
override def readExternal(in: ObjectInput): Unit = {
counterReset = in.readInt()
}
}