Package

org.apache.spark

serializer

Permalink

package serializer

Pluggable serializers for RDD and shuffle data.

See also

org.apache.spark.serializer.Serializer

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. serializer
  2. AnyRef
  3. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Type Members

  1. abstract class DeserializationStream extends AnyRef

    Permalink

    :: DeveloperApi :: A stream for reading serialized objects.

    :: DeveloperApi :: A stream for reading serialized objects.

    Annotations
    @DeveloperApi()
  2. final class DummySerializerInstance extends SerializerInstance

    Permalink
  3. class JavaSerializer extends Serializer with Externalizable

    Permalink

    :: DeveloperApi :: A Spark serializer that uses Java's built-in serialization.

    :: DeveloperApi :: A Spark serializer that uses Java's built-in serialization.

    Annotations
    @DeveloperApi()
    Note

    This serializer is not guaranteed to be wire-compatible across different versions of Spark. It is intended to be used to serialize/de-serialize data within a single Spark application.

  4. trait KryoRegistrator extends AnyRef

    Permalink

    Interface implemented by clients to register their classes with Kryo when using Kryo serialization.

  5. class KryoSerializer extends Serializer with internal.Logging with Serializable

    Permalink

    A Spark serializer that uses the Kryo serialization library.

    A Spark serializer that uses the Kryo serialization library.

    Note

    This serializer is not guaranteed to be wire-compatible across different versions of Spark. It is intended to be used to serialize/de-serialize data within a single Spark application.

  6. final class PooledKryoSerializer extends KryoSerializer with Serializable

    Permalink

    A pooled, optimized version of Spark's KryoSerializer that also works for closure serialization.

    A pooled, optimized version of Spark's KryoSerializer that also works for closure serialization.

    Note that this serializer is not guaranteed to be wire-compatible across different versions of Spark. It is intended to be used to serialize/de-serialize data within a single Spark application.

  7. final class PooledObject extends AnyRef

    Permalink
  8. abstract class SerializationStream extends AnyRef

    Permalink

    :: DeveloperApi :: A stream for writing serialized objects.

    :: DeveloperApi :: A stream for writing serialized objects.

    Annotations
    @DeveloperApi()
  9. abstract class Serializer extends AnyRef

    Permalink

    :: DeveloperApi :: A serializer.

    :: DeveloperApi :: A serializer. Because some serialization libraries are not thread safe, this class is used to create org.apache.spark.serializer.SerializerInstance objects that do the actual serialization and are guaranteed to only be called from one thread at a time.

    Implementations of this trait should implement:

    1. a zero-arg constructor or a constructor that accepts a org.apache.spark.SparkConf as parameter. If both constructors are defined, the latter takes precedence.

    2. Java serialization interface.

    Annotations
    @DeveloperApi()
    Note

    Serializers are not required to be wire-compatible across different versions of Spark. They are intended to be used to serialize/de-serialize data within a single Spark application.

  10. abstract class SerializerInstance extends AnyRef

    Permalink

    :: DeveloperApi :: An instance of a serializer, for use by one thread at a time.

    :: DeveloperApi :: An instance of a serializer, for use by one thread at a time.

    It is legal to create multiple serialization / deserialization streams from the same SerializerInstance as long as those streams are all used within the same thread.

    Annotations
    @DeveloperApi() @NotThreadSafe()
  11. class SnappyKryoSerializerFactory extends SerializerFactory

    Permalink

    This serializer factory will instantiate new serializers of a given class via reflection.

    This serializer factory will instantiate new serializers of a given class via reflection. If the class implements Serializable and has either of writeReplace/readResolve/readObject/writeObject then it will set JavaSerializer for that class else FieldSerailizer will be used

Value Members

  1. object ConnectionPropertiesSerializer extends com.esotericsoftware.kryo.Serializer[ConnectionProperties]

    Permalink
  2. object KryoSerializerPool

    Permalink
  3. object PartitionResultSerializer extends com.esotericsoftware.kryo.Serializer[PartitionResult]

    Permalink
  4. object StructTypeSerializer extends com.esotericsoftware.kryo.Serializer[StructType]

    Permalink

Inherited from AnyRef

Inherited from Any

Ungrouped