Object

org.apache.spark.sql.execution.columnar.impl

StoreCallbacksImpl

Related Doc: package impl

Permalink

object StoreCallbacksImpl extends StoreCallbacks with Logging with Serializable

Linear Supertypes
Serializable, Serializable, Logging, StoreCallbacks, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. StoreCallbacksImpl
  2. Serializable
  3. Serializable
  4. Logging
  5. StoreCallbacks
  6. AnyRef
  7. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

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(objectName: String, numBytes: Long, buffer: UMMMemoryTracker, shouldEvict: Boolean, offHeap: Boolean): Boolean

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  5. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  6. def clearConnectionPools(): Unit

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  7. def clearSessionCache(onlyQueryPlanCache: Boolean = false): Unit

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  8. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  9. def columnBatchTableName(table: String): String

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  10. def columnTableScan(columnTable: String, projection: Array[Int], serializedFilters: Array[Byte], bucketIds: Set[Integer]): CloseableIterator[ColumnTableEntry]

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
    Annotations
    @throws( classOf[SQLException] )
  11. def createColumnBatch(region: BucketRegion, batchID: Long, bucketID: Int): Set[AnyRef]

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  12. def dropStorageMemory(objectName: String, ignoreBytes: Long): Unit

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  13. final def eq(arg0: AnyRef): Boolean

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

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

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

    Permalink
    Definition Classes
    AnyRef → Any
  17. def getExecutionPoolSize(offHeap: Boolean): Long

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  18. def getExecutionPoolUsedMemory(offHeap: Boolean): Long

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  19. def getHashCodeSnappy(dvds: Array[AnyRef], numPartitions: Int): Int

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  20. def getHashCodeSnappy(dvd: Any, numPartitions: Int): Int

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  21. def getInternalTableSchemas(): List[String]

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  22. def getLastIndexOfRow(o: AnyRef): Int

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  23. def getLeadClassLoader(): URLClassLoader

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  24. def getOffHeapMemory(objectName: String): Long

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  25. def getSnappyTableStats(): AnyRef

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  26. def getStoragePoolSize(offHeap: Boolean): Long

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  27. def getStoragePoolUsedMemory(offHeap: Boolean): Long

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  28. def hasOffHeap(): Boolean

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  29. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  30. def initMemoryStats(stats: MemoryManagerStats): Unit

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  31. def initializeLogIfNecessary(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  32. def invokeColumnStorePutCallbacks(bucket: BucketRegion, events: Array[EntryEventImpl]): Unit

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  33. def isColumnTable(qualifiedName: String): Boolean

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  34. final def isDebugEnabled: Boolean

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

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

    Permalink
    Definition Classes
    Any
  37. def isSnappyStore(): Boolean

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  38. final def isTraceEnabled: Boolean

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

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

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

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

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

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  47. def logMemoryStats(): Unit

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  48. def logName: String

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

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

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

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

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

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

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

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

    Permalink
    Definition Classes
    AnyRef
  57. def performConnectorOp(ctx: AnyRef): Unit

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  58. def refreshPolicies(ldapGroup: String): Unit

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  59. def registerRelationDestroyForHiveStore(): Unit

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  60. def registerTypes(): Unit

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  61. def releaseStorageMemory(objectName: String, numBytes: Long, offHeap: Boolean): Unit

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  62. def resetLogger(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  63. def resetMemoryManager(): Unit

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  64. def shouldStopRecovery(): Boolean

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  65. def skipEvictionForEntry(entry: LRUEntry): Boolean

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks
  66. final def synchronized[T0](arg0: ⇒ T0): T0

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

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

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  71. def waitForRuntimeManager(maxWaitMillis: Long): Unit

    Permalink
    Definition Classes
    StoreCallbacksImpl → StoreCallbacks

Inherited from Serializable

Inherited from Serializable

Inherited from Logging

Inherited from StoreCallbacks

Inherited from AnyRef

Inherited from Any

Ungrouped