Class

org.apache.spark.memory

DefaultMemoryManager

Related Doc: package memory

Permalink

class DefaultMemoryManager extends StoreUnifiedManager with Logging

Linear Supertypes
Logging, StoreUnifiedManager, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. DefaultMemoryManager
  2. Logging
  3. StoreUnifiedManager
  4. AnyRef
  5. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new DefaultMemoryManager()

    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 acquireStorageMemoryForObject(objectName: String, blockId: BlockId, numBytes: Long, memoryMode: MemoryMode, buffer: UMMMemoryTracker, shouldEvict: Boolean): Boolean

    Permalink
  5. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  6. def bootManager: Boolean

    Permalink
  7. def changeOffHeapOwnerToStorage(buffer: ByteBuffer, allowNonAllocator: Boolean): Unit

    Permalink

    Change the off-heap owner to mark it being used for storage.

    Change the off-heap owner to mark it being used for storage. Passing the owner as null allows moving ByteBuffers not allocated by BufferAllocators to be also changed and freshly accounted.

    Definition Classes
    DefaultMemoryManagerStoreUnifiedManager
  8. def clear(): Unit

    Permalink

    Clears the internal map

    Clears the internal map

    Definition Classes
    DefaultMemoryManagerStoreUnifiedManager
  9. def clone(): AnyRef

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

    Permalink

    Closes the memory manager.

    Closes the memory manager.

    Definition Classes
    DefaultMemoryManagerStoreUnifiedManager
  11. def dropStorageMemoryForObject(objectName: String, memoryMode: MemoryMode, ignoreNumBytes: Long): Long

    Permalink
  12. final def eq(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    AnyRef → Any
  14. def finalize(): Unit

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

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

    Permalink
  17. def getExecutionPoolUsedMemory(memoryMode: MemoryMode): Long

    Permalink
  18. def getOffHeapMemory(objectName: String): Long

    Permalink
  19. def getStoragePoolMemoryUsed(memoryMode: MemoryMode): Long

    Permalink
  20. def getStoragePoolSize(memoryMode: MemoryMode): Long

    Permalink
  21. def hasOffHeap: Boolean

    Permalink
  22. def hashCode(): Int

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

    Permalink

    Initializes the memoryManager

    Initializes the memoryManager

    Definition Classes
    DefaultMemoryManagerStoreUnifiedManager
  24. def initMemoryStats(stats: MemoryManagerStats): Unit

    Permalink
  25. def initializeLogIfNecessary(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  26. final def isDebugEnabled: Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  27. final def isInfoEnabled: Boolean

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

    Permalink
    Definition Classes
    Any
  29. final def isTraceEnabled: Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  30. final var levelFlags: Int

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

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

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

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

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

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  39. def logStats(): Unit

    Permalink
  40. def logTrace(msg: ⇒ String, throwable: Throwable): Unit

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  44. final var log_: Logger

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  45. final def ne(arg0: AnyRef): Boolean

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

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

    Permalink
    Definition Classes
    AnyRef
  48. def releaseStorageMemoryForObject(objectName: String, numBytes: Long, memoryMode: MemoryMode): Unit

    Permalink
  49. def resetLogger(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  50. def shouldStopRecovery(): Boolean

    Permalink
  51. final def synchronized[T0](arg0: ⇒ T0): T0

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

    Permalink
    Definition Classes
    AnyRef → Any
  53. final def wait(): Unit

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

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

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

Inherited from Logging

Inherited from StoreUnifiedManager

Inherited from AnyRef

Inherited from Any

Ungrouped