object StreamingSymmetricHashJoinHelper extends Logging
Helper object for StreamingSymmetricHashJoinExec. See that object for more details.
- Alphabetic
- By Inheritance
- StreamingSymmetricHashJoinHelper
- Logging
- AnyRef
- Any
- Hide All
- Show All
- Public
- All
Type Members
-
case class
JoinConditionSplitPredicates(leftSideOnly: Option[Expression], rightSideOnly: Option[Expression], bothSides: Option[Expression], full: Option[Expression]) extends Product with Serializable
Wrapper around various useful splits of the join condition.
Wrapper around various useful splits of the join condition. left AND right AND joined is equivalent to full.
Note that left and right do not necessarily contain *all* conjuncts which satisfy their condition.
- leftSideOnly
Deterministic conjuncts which reference only the left side of the join.
- rightSideOnly
Deterministic conjuncts which reference only the right side of the join.
- bothSides
Conjuncts which are nondeterministic, occur after a nondeterministic conjunct, or reference both left and right sides of the join.
- full
The full join condition.
- sealed trait JoinSide extends AnyRef
-
case class
JoinStateKeyWatermarkPredicate(expr: Expression) extends JoinStateWatermarkPredicate with Product with Serializable
Predicate for watermark on state keys
-
case class
JoinStateValueWatermarkPredicate(expr: Expression) extends JoinStateWatermarkPredicate with Product with Serializable
Predicate for watermark on state values
- sealed trait JoinStateWatermarkPredicate extends AnyRef
- case class JoinStateWatermarkPredicates(left: Option[JoinStateWatermarkPredicate] = None, right: Option[JoinStateWatermarkPredicate] = None) extends Product with Serializable
- implicit class StateStoreAwareZipPartitionsHelper[T] extends AnyRef
-
class
StateStoreAwareZipPartitionsRDD[A, B, V] extends ZippedPartitionsBaseRDD[V]
A custom RDD that allows partitions to be "zipped" together, while ensuring the tasks' preferred location is based on which executors have the required join state stores already loaded.
A custom RDD that allows partitions to be "zipped" together, while ensuring the tasks' preferred location is based on which executors have the required join state stores already loaded. This class is a variant of ZippedPartitionsRDD2 which only changes signature of
f
.
Value Members
-
final
def
!=(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
-
final
def
##(): Int
- Definition Classes
- AnyRef → Any
-
final
def
==(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
-
final
def
asInstanceOf[T0]: T0
- Definition Classes
- Any
-
def
clone(): AnyRef
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws( ... ) @native()
-
final
def
eq(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
-
def
equals(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
-
def
finalize(): Unit
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws( classOf[java.lang.Throwable] )
-
final
def
getClass(): Class[_]
- Definition Classes
- AnyRef → Any
- Annotations
- @native()
-
def
getStateWatermarkPredicates(leftAttributes: Seq[Attribute], rightAttributes: Seq[Attribute], leftKeys: Seq[Expression], rightKeys: Seq[Expression], condition: Option[Expression], eventTimeWatermark: Option[Long]): JoinStateWatermarkPredicates
Get the predicates defining the state watermarks for both sides of the join
-
def
hashCode(): Int
- Definition Classes
- AnyRef → Any
- Annotations
- @native()
-
def
initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean): Boolean
- Attributes
- protected
- Definition Classes
- Logging
-
def
initializeLogIfNecessary(isInterpreter: Boolean): Unit
- Attributes
- protected
- Definition Classes
- Logging
-
final
def
isInstanceOf[T0]: Boolean
- Definition Classes
- Any
-
def
isTraceEnabled(): Boolean
- Attributes
- protected
- Definition Classes
- Logging
-
def
log: Logger
- Attributes
- protected
- Definition Classes
- Logging
-
def
logDebug(msg: ⇒ String, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
-
def
logDebug(msg: ⇒ String): Unit
- Attributes
- protected
- Definition Classes
- Logging
-
def
logError(msg: ⇒ String, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
-
def
logError(msg: ⇒ String): Unit
- Attributes
- protected
- Definition Classes
- Logging
-
def
logInfo(msg: ⇒ String, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
-
def
logInfo(msg: ⇒ String): Unit
- Attributes
- protected
- Definition Classes
- Logging
-
def
logName: String
- Attributes
- protected
- Definition Classes
- Logging
-
def
logTrace(msg: ⇒ String, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
-
def
logTrace(msg: ⇒ String): Unit
- Attributes
- protected
- Definition Classes
- Logging
-
def
logWarning(msg: ⇒ String, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
-
def
logWarning(msg: ⇒ String): Unit
- Attributes
- protected
- Definition Classes
- Logging
-
final
def
ne(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
-
final
def
notify(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native()
-
final
def
notifyAll(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native()
-
final
def
synchronized[T0](arg0: ⇒ T0): T0
- Definition Classes
- AnyRef
-
def
toString(): String
- Definition Classes
- AnyRef → Any
-
final
def
wait(): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws( ... )
-
final
def
wait(arg0: Long, arg1: Int): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws( ... )
-
final
def
wait(arg0: Long): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws( ... ) @native()
- object JoinConditionSplitPredicates extends PredicateHelper with Serializable
- object LeftSide extends JoinSide with Product with Serializable
- object RightSide extends JoinSide with Product with Serializable