Class/Object

org.apache.spark.memory

SnappyUnifiedMemoryManager

Related Docs: object SnappyUnifiedMemoryManager | package memory

Permalink

class SnappyUnifiedMemoryManager extends UnifiedMemoryManager with StoreUnifiedManager with StoreCallback

When there is request for execution or storage memory, critical up and eviction up events are checked. If they are set, try to free the memory cached by Spark rdds by calling memoryStore.evictBlocksToFreeSpace. If enough memory cannot be freed, return the call and let Spark take a corrective action. In such cases Spark either fails the task or move the current RDDs data to disk. If the critical and eviction events are not set, it asks the UnifiedMemoryManager to allocate the space.

Self Type
SnappyUnifiedMemoryManager
Linear Supertypes
StoreCallback, Serializable, Serializable, StoreUnifiedManager, UnifiedMemoryManager, MemoryManager, internal.Logging, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. SnappyUnifiedMemoryManager
  2. StoreCallback
  3. Serializable
  4. Serializable
  5. StoreUnifiedManager
  6. UnifiedMemoryManager
  7. MemoryManager
  8. Logging
  9. AnyRef
  10. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new SnappyUnifiedMemoryManager(conf: SparkConf, numCores: Int)

    Permalink
  2. new SnappyUnifiedMemoryManager(conf: SparkConf, numCores: Int, tempManager: Boolean = false)

    Permalink

Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  4. def acquireStorageMemory(blockId: BlockId, numBytes: Long, memoryMode: MemoryMode): Boolean

    Permalink
    Definition Classes
    SnappyUnifiedMemoryManager → UnifiedMemoryManager → MemoryManager
  5. def acquireStorageMemoryForObject(objectName: String, blockId: BlockId, numBytes: Long, memoryMode: MemoryMode, buffer: UMMMemoryTracker, shouldEvict: Boolean): Boolean

    Permalink
    Definition Classes
    SnappyUnifiedMemoryManager → StoreUnifiedManager
  6. def acquireUnrollMemory(blockId: BlockId, numBytes: Long, memoryMode: MemoryMode): Boolean

    Permalink
    Definition Classes
    UnifiedMemoryManager → MemoryManager
  7. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  8. def assertInvariants(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    UnifiedMemoryManager
  9. val bootManager: Boolean

    Permalink
    Definition Classes
    SnappyUnifiedMemoryManager → StoreUnifiedManager
  10. def changeOffHeapOwnerToStorage(buffer: ByteBuffer, allowNonAllocator: Boolean): Unit

    Permalink
    Definition Classes
    SnappyUnifiedMemoryManager → StoreUnifiedManager
  11. def clear(): Unit

    Permalink

    Clears the internal map

    Clears the internal map

    Definition Classes
    SnappyUnifiedMemoryManager → StoreUnifiedManager
  12. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  13. def close(): Unit

    Permalink

    This method will be called if executor is going to be restarted.

    This method will be called if executor is going to be restarted. When executor is coming up all accounting from store will be done in bootMemoryManager. When executor stops we will copy the existing entry in this manager to boot manager. Once executor comes back again we will again copy the boot manager entries to run time manager.

    Definition Classes
    SnappyUnifiedMemoryManager → StoreUnifiedManager
  14. def dropStorageMemoryForObject(name: String, memoryMode: MemoryMode, ignoreNumBytes: Long): Long

    Permalink
    Definition Classes
    SnappyUnifiedMemoryManager → StoreUnifiedManager
  15. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  16. def equals(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  17. final def executionMemoryUsed: Long

    Permalink
    Definition Classes
    MemoryManager
  18. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  19. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  20. def getExecutionPoolSize(memoryMode: MemoryMode): Long

    Permalink
    Definition Classes
    SnappyUnifiedMemoryManager → StoreUnifiedManager
  21. def getExecutionPoolUsedMemory(memoryMode: MemoryMode): Long

    Permalink
    Definition Classes
    SnappyUnifiedMemoryManager → StoreUnifiedManager
  22. def getOffHeapMemory(objectName: String): Long

    Permalink
    Definition Classes
    SnappyUnifiedMemoryManager → StoreUnifiedManager
  23. def getStoragePoolMemoryUsed(memoryMode: MemoryMode): Long

    Permalink
    Definition Classes
    SnappyUnifiedMemoryManager → StoreUnifiedManager
  24. def getStoragePoolSize(memoryMode: MemoryMode): Long

    Permalink
    Definition Classes
    SnappyUnifiedMemoryManager → StoreUnifiedManager
  25. def hasOffHeap: Boolean

    Permalink
    Definition Classes
    SnappyUnifiedMemoryManager → StoreUnifiedManager
  26. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  27. def init(): Unit

    Permalink

    Initializes the memoryManager

    Initializes the memoryManager

    Definition Classes
    SnappyUnifiedMemoryManager → StoreUnifiedManager
  28. def initMemoryStats(stats: MemoryManagerStats): Unit

    Permalink
    Definition Classes
    SnappyUnifiedMemoryManager → StoreUnifiedManager
  29. def initializeLogIfNecessary(isInterpreter: Boolean): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  30. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  31. def isTraceEnabled(): Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  32. def log: Logger

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  33. def logDebug(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  34. def logDebug(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  35. def logError(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  36. def logError(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  37. def logInfo(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  38. def logInfo(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  39. def logName: String

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  40. def logStats(tag: String): Unit

    Permalink
  41. def logStats(): Unit

    Permalink
    Definition Classes
    SnappyUnifiedMemoryManager → StoreUnifiedManager
  42. def logTrace(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  43. def logTrace(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  44. def logWarning(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  45. def logWarning(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  46. val maxHeapMemory: Long

    Permalink

    the maximum heap memory that is available for use by MemoryManager; callers should leave out some amount of "reserved memory" for unaccounted object allocations

    the maximum heap memory that is available for use by MemoryManager; callers should leave out some amount of "reserved memory" for unaccounted object allocations

    Definition Classes
    SnappyUnifiedMemoryManager → UnifiedMemoryManager
  47. val maxOffHeapMemory: Long

    Permalink
    Attributes
    protected[this]
    Definition Classes
    MemoryManager
  48. def maxOffHeapStorageMemory: Long

    Permalink
    Definition Classes
    UnifiedMemoryManager → MemoryManager
  49. def maxOnHeapStorageMemory: Long

    Permalink
    Definition Classes
    UnifiedMemoryManager → MemoryManager
  50. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  51. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  52. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  53. val offHeapExecutionMemoryPool: ExecutionMemoryPool

    Permalink
    Attributes
    protected
    Definition Classes
    MemoryManager
  54. val offHeapStorageMemory: Long

    Permalink
    Attributes
    protected[this]
    Definition Classes
    MemoryManager
  55. val offHeapStorageMemoryPool: StorageMemoryPool

    Permalink
    Attributes
    protected
    Definition Classes
    MemoryManager
  56. val onHeapExecutionMemoryPool: ExecutionMemoryPool

    Permalink
    Attributes
    protected
    Definition Classes
    MemoryManager
  57. val onHeapStorageMemoryPool: StorageMemoryPool

    Permalink
    Attributes
    protected
    Definition Classes
    MemoryManager
  58. val pageSizeBytes: Long

    Permalink
    Definition Classes
    MemoryManager
  59. final def releaseAllStorageMemory(): Unit

    Permalink
    Definition Classes
    MemoryManager
  60. def releaseExecutionMemory(numBytes: Long, taskAttemptId: Long, memoryMode: MemoryMode): Unit

    Permalink
    Definition Classes
    SnappyUnifiedMemoryManager → MemoryManager
  61. def releaseStorageMemory(numBytes: Long, memoryMode: MemoryMode): Unit

    Permalink
    Definition Classes
    SnappyUnifiedMemoryManager → MemoryManager
  62. def releaseStorageMemoryForObject(objectName: String, numBytes: Long, memoryMode: MemoryMode): Unit

    Permalink
    Definition Classes
    SnappyUnifiedMemoryManager → StoreUnifiedManager
  63. final def releaseUnrollMemory(numBytes: Long, memoryMode: MemoryMode): Unit

    Permalink
    Definition Classes
    MemoryManager
  64. final def setMemoryStore(store: MemoryStore): Unit

    Permalink
    Definition Classes
    MemoryManager
  65. def shouldStopRecovery(): Boolean

    Permalink
    Definition Classes
    SnappyUnifiedMemoryManager → StoreUnifiedManager
  66. final def storageMemoryUsed: Long

    Permalink
    Definition Classes
    MemoryManager
  67. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  68. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  69. def tryExplicitGC(numBytes: Long): Unit

    Permalink
  70. final val tungstenMemoryMode: MemoryMode

    Permalink
    Definition Classes
    MemoryManager
  71. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  72. final def wait(arg0: Long, arg1: Int): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  73. final def wait(arg0: Long): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from StoreCallback

Inherited from Serializable

Inherited from Serializable

Inherited from StoreUnifiedManager

Inherited from UnifiedMemoryManager

Inherited from MemoryManager

Inherited from internal.Logging

Inherited from AnyRef

Inherited from Any

Ungrouped