Class BlockId

Object
org.apache.spark.storage.BlockId
Direct Known Subclasses:
BroadcastBlockId, CacheId, RDDBlockId, ShuffleBlockBatchId, ShuffleBlockChunkId, ShuffleBlockId, ShuffleChecksumBlockId, ShuffleDataBlockId, ShuffleIndexBlockId, ShuffleMergedBlockId, ShuffleMergedDataBlockId, ShuffleMergedIndexBlockId, ShuffleMergedMetaBlockId, ShufflePushBlockId, StreamBlockId, TaskResultBlockId

public abstract class BlockId extends Object
:: DeveloperApi :: Identifies a particular Block of data, usually associated with a single file. A Block can be uniquely identified by its filename, but each type of Block has a different set of keys which produce its unique name.

If your BlockId should be serializable, be sure to add it to the BlockId.apply() method.

  • Constructor Details

    • BlockId

      public BlockId()
  • Method Details

    • RDD

      public static scala.util.matching.Regex RDD()
    • SHUFFLE

      public static scala.util.matching.Regex SHUFFLE()
    • SHUFFLE_BATCH

      public static scala.util.matching.Regex SHUFFLE_BATCH()
    • SHUFFLE_DATA

      public static scala.util.matching.Regex SHUFFLE_DATA()
    • SHUFFLE_INDEX

      public static scala.util.matching.Regex SHUFFLE_INDEX()
    • SHUFFLE_PUSH

      public static scala.util.matching.Regex SHUFFLE_PUSH()
    • SHUFFLE_MERGED

      public static scala.util.matching.Regex SHUFFLE_MERGED()
    • SHUFFLE_MERGED_DATA

      public static scala.util.matching.Regex SHUFFLE_MERGED_DATA()
    • SHUFFLE_MERGED_INDEX

      public static scala.util.matching.Regex SHUFFLE_MERGED_INDEX()
    • SHUFFLE_MERGED_META

      public static scala.util.matching.Regex SHUFFLE_MERGED_META()
    • SHUFFLE_CHUNK

      public static scala.util.matching.Regex SHUFFLE_CHUNK()
    • BROADCAST

      public static scala.util.matching.Regex BROADCAST()
    • TASKRESULT

      public static scala.util.matching.Regex TASKRESULT()
    • STREAM

      public static scala.util.matching.Regex STREAM()
    • TEMP_LOCAL

      public static scala.util.matching.Regex TEMP_LOCAL()
    • TEMP_SHUFFLE

      public static scala.util.matching.Regex TEMP_SHUFFLE()
    • TEST

      public static scala.util.matching.Regex TEST()
    • apply

      public static BlockId apply(String name)
    • name

      public abstract String name()
      A globally unique identifier for this Block. Can be used for ser/de.
    • asRDDId

      public scala.Option<RDDBlockId> asRDDId()
    • isRDD

      public boolean isRDD()
    • isShuffle

      public boolean isShuffle()
    • isShuffleChunk

      public boolean isShuffleChunk()
    • isBroadcast

      public boolean isBroadcast()
    • toString

      public String toString()
      Overrides:
      toString in class Object