class SolrPredicateRules extends CassandraPredicateRules with Logging
- Alphabetic
- By Inheritance
- SolrPredicateRules
- Logging
- CassandraPredicateRules
- AnyRef
- Any
- Hide All
- Show All
- Public
- All
Instance Constructors
- new SolrPredicateRules(searchOptimizationEnabled: DseSearchOptimizationSetting)
Type Members
- case class SolrFilter(solrQuery: String, references: Array[String]) extends Product with Serializable
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
- def alreadyContainsSolrQuery(predicates: AnalyzedPredicates): Boolean
-
def
apply(predicates: AnalyzedPredicates, tableDef: TableDef, sparkConf: SparkConf): AnalyzedPredicates
Entry point for Spark Cassandra Connector.
Entry point for Spark Cassandra Connector. Reads SolrIndexedColumn information from C*. See above Apply method for actual implementation.
- Definition Classes
- SolrPredicateRules → CassandraPredicateRules
-
final
def
asInstanceOf[T0]: T0
- Definition Classes
- Any
-
def
clone(): AnyRef
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws( ... ) @native() @HotSpotIntrinsicCandidate()
- def convertToSolrFilter(filter: Filter): SolrFilter
-
def
convertToSolrQuery(predicates: AnalyzedPredicates, tableDef: TableDef, solrIndexedFields: Set[String], searchOptimizationEnabled: DseSearchOptimizationSetting, sparkConf: SparkConf): AnalyzedPredicates
For all top level filters.
For all top level filters. If the filter can be changed into a SolrQuery we will convert it and mark it as handled by Cassandra. All other filters will be filtered within Spark
-
final
def
eq(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
-
def
equals(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- def escapeSolrCondition(condition: String): String
-
def
findUselessIsNotNulls(filters: Set[Filter], tableDef: TableDef): Set[IsNotNull]
Whenever we have an attribute filter we don't need to do an IS_NOT_NULL check.
Whenever we have an attribute filter we don't need to do an IS_NOT_NULL check. This also helps when we remove partition key restrictions because we don't keep useless IsNotNulls which generate bad Solr.
-
final
def
getClass(): Class[_]
- Definition Classes
- AnyRef → Any
- Annotations
- @native() @HotSpotIntrinsicCandidate()
-
def
getPartitionKeyRestriction(predicates: AnalyzedPredicates, tableDef: TableDef): Set[EqualTo]
Returns all predicates that can be treated as a single partition restriction.
Returns all predicates that can be treated as a single partition restriction.
Follows the same rules as in SCC Basic Cassandra Predicates
If no single partition restriction can be found returns nothing.
-
def
getSolrIndexedColumnsFromSolrXML(tableDef: TableDef, sparkConf: SparkConf): Set[String]
Unfortunately the easiest current way to remotely determine what columns have been indexed by solr is to read the Schema.xml.
Unfortunately the easiest current way to remotely determine what columns have been indexed by solr is to read the Schema.xml. To obtain this we check the Cassandra solr_admin table and pull the text from the schema.xml.bak.
Schema.xml.bak is the current "live" schema while schema.xml is the schema that will be applied on refresh.
-
def
hashCode(): Int
- Definition Classes
- AnyRef → Any
- Annotations
- @native() @HotSpotIntrinsicCandidate()
-
def
isConvertibleToSolr(filter: Filter, indexedCols: Set[String]): Boolean
Checks that the filter and all dependent filters are indexed by SolrIndexes.
-
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() @HotSpotIntrinsicCandidate()
-
final
def
notifyAll(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native() @HotSpotIntrinsicCandidate()
-
final
def
synchronized[T0](arg0: ⇒ T0): T0
- Definition Classes
- AnyRef
-
def
toString(): String
- Definition Classes
- AnyRef → Any
-
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()
-
final
def
wait(): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws( ... )
Deprecated Value Members
-
def
finalize(): Unit
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws( classOf[java.lang.Throwable] ) @Deprecated @deprecated
- Deprecated
(Since version ) see corresponding Javadoc for more information.