Skip to content
This repository has been archived by the owner on Jun 14, 2024. It is now read-only.

Commit

Permalink
types.covering -> covering
Browse files Browse the repository at this point in the history
  • Loading branch information
Chungmin Lee committed Jul 2, 2021
1 parent 5dfb24a commit 7f10ec7
Show file tree
Hide file tree
Showing 30 changed files with 32 additions and 32 deletions.
2 changes: 1 addition & 1 deletion python/hyperspace/hyperspace.py
Original file line number Diff line number Diff line change
Expand Up @@ -29,7 +29,7 @@ def _getJavaIndexConfig(self, index_config):
"""
indexed_columns = self._getScalaSeqFromList(index_config.indexedColumns)
included_columns = self._getScalaSeqFromList(index_config.includedColumns)
_jindexConfig = self.jvm.com.microsoft.hyperspace.index.types.covering.CoveringIndexConfig(
_jindexConfig = self.jvm.com.microsoft.hyperspace.index.covering.CoveringIndexConfig(
self.jvm.java.lang.String(index_config.indexName), indexed_columns, included_columns)
return _jindexConfig

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,7 @@
* limitations under the License.
*/

package com.microsoft.hyperspace.index.types.covering
package com.microsoft.hyperspace.index.covering

import org.apache.spark.sql.{DataFrame, SaveMode}
import org.apache.spark.sql.catalyst.catalog.BucketSpec
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,7 @@
* limitations under the License.
*/

package com.microsoft.hyperspace.index.types.covering
package com.microsoft.hyperspace.index.covering

import java.util.Locale

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,7 @@
* limitations under the License.
*/

package com.microsoft.hyperspace.index.types.covering
package com.microsoft.hyperspace.index.covering

import org.apache.spark.sql.catalyst.plans.logical.LogicalPlan

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,7 @@
* limitations under the License.
*/

package com.microsoft.hyperspace.index.types.covering
package com.microsoft.hyperspace.index.covering

import org.apache.spark.sql.SparkSession
import org.apache.spark.sql.catalyst.plans.logical.LogicalPlan
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,7 @@
* limitations under the License.
*/

package com.microsoft.hyperspace.index.types.covering
package com.microsoft.hyperspace.index.covering

import org.apache.spark.sql.catalyst.analysis.CleanupAliases
import org.apache.spark.sql.catalyst.expressions.{AttributeReference, Expression}
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,7 @@
* limitations under the License.
*/

package com.microsoft.hyperspace.index.types.covering
package com.microsoft.hyperspace.index.covering

import org.apache.spark.sql.SparkSession
import org.apache.spark.sql.catalyst.plans.logical.LogicalPlan
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,7 @@
* limitations under the License.
*/

package com.microsoft.hyperspace.index.types.covering
package com.microsoft.hyperspace.index.covering

import scala.collection.mutable
import scala.util.Try
Expand All @@ -25,10 +25,10 @@ import org.apache.spark.sql.catalyst.plans.logical.{LeafNode, LogicalPlan}

import com.microsoft.hyperspace.Hyperspace
import com.microsoft.hyperspace.index.{IndexLogEntry, IndexLogEntryTags}
import com.microsoft.hyperspace.index.covering.JoinAttributeFilter.extractConditions
import com.microsoft.hyperspace.index.rules.{HyperspaceRule, IndexRankFilter, QueryPlanIndexFilter}
import com.microsoft.hyperspace.index.rules.ApplyHyperspace.{PlanToIndexesMap, PlanToSelectedIndexMap}
import com.microsoft.hyperspace.index.sources.FileBasedRelation
import com.microsoft.hyperspace.index.types.covering.JoinAttributeFilter.extractConditions
import com.microsoft.hyperspace.shim.JoinWithoutHint
import com.microsoft.hyperspace.telemetry.{AppInfo, HyperspaceEventLogging, HyperspaceIndexUsageEvent}
import com.microsoft.hyperspace.util.ResolverUtils.resolve
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,7 @@
* limitations under the License.
*/

package com.microsoft.hyperspace.index.types.covering
package com.microsoft.hyperspace.index.covering

import org.apache.hadoop.fs.Path
import org.apache.spark.sql.SparkSession
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -16,7 +16,7 @@

package com.microsoft.hyperspace

import com.microsoft.hyperspace.index.types.covering.CoveringIndexConfig
import com.microsoft.hyperspace.index.covering.CoveringIndexConfig

package object index {

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -20,8 +20,8 @@ import scala.collection.mutable

import org.apache.spark.sql.catalyst.plans.logical.LogicalPlan

import com.microsoft.hyperspace.index.covering.{FilterIndexRule, JoinIndexRule}
import com.microsoft.hyperspace.index.rules.ApplyHyperspace.PlanToIndexesMap
import com.microsoft.hyperspace.index.types.covering.{FilterIndexRule, JoinIndexRule}

/**
* Apply Hyperspace indexes based on the score of each index application.
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -27,8 +27,8 @@ import org.mockito.Mockito.{mock, when}
import com.microsoft.hyperspace.{HyperspaceException, SampleData}
import com.microsoft.hyperspace.actions.Constants.States.{ACTIVE, CREATING}
import com.microsoft.hyperspace.index._
import com.microsoft.hyperspace.index.covering.CoveringIndex
import com.microsoft.hyperspace.index.sources.FileBasedSourceProviderManager
import com.microsoft.hyperspace.index.types.covering.CoveringIndex

class RefreshActionTest extends HyperspaceSuite {
private val sampleParquetDataLocation = inTempDir("sampleparquet")
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -28,9 +28,9 @@ import com.microsoft.hyperspace.{Hyperspace, Implicits, SampleData, TestConfig,
import com.microsoft.hyperspace.actions.Constants
import com.microsoft.hyperspace.index.IndexConstants.{GLOBBING_PATTERN_KEY, REFRESH_MODE_INCREMENTAL, REFRESH_MODE_QUICK}
import com.microsoft.hyperspace.index.IndexLogEntryTags._
import com.microsoft.hyperspace.index.covering.JoinIndexRule
import com.microsoft.hyperspace.index.execution.BucketUnionStrategy
import com.microsoft.hyperspace.index.rules.{ApplyHyperspace, CandidateIndexCollector}
import com.microsoft.hyperspace.index.types.covering.JoinIndexRule
import com.microsoft.hyperspace.util.PathUtils

class E2EHyperspaceRulesTest extends QueryTest with HyperspaceSuite {
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -27,7 +27,7 @@ import org.apache.spark.sql.types.{StructField, StructType}
import com.microsoft.hyperspace.HyperspaceException
import com.microsoft.hyperspace.actions.Constants
import com.microsoft.hyperspace.index.Hdfs.Properties
import com.microsoft.hyperspace.index.types.covering.CoveringIndex
import com.microsoft.hyperspace.index.covering.CoveringIndex
import com.microsoft.hyperspace.util.PathUtils

trait HyperspaceRuleSuite extends HyperspaceSuite {
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -23,7 +23,7 @@ import org.apache.spark.sql.types.{StringType, StructField, StructType}

import com.microsoft.hyperspace.{Hyperspace, HyperspaceException, SampleData}
import com.microsoft.hyperspace.actions.Constants
import com.microsoft.hyperspace.index.types.covering.CoveringIndex
import com.microsoft.hyperspace.index.covering.CoveringIndex
import com.microsoft.hyperspace.util.FileUtils

class IndexCacheTest extends HyperspaceSuite {
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -25,7 +25,7 @@ import org.mockito.Mockito.{mock, when}
import com.microsoft.hyperspace.HyperspaceException
import com.microsoft.hyperspace.actions.Constants
import com.microsoft.hyperspace.index.IndexConstants.{REFRESH_MODE_FULL, REFRESH_MODE_INCREMENTAL}
import com.microsoft.hyperspace.index.types.covering.CoveringIndex
import com.microsoft.hyperspace.index.covering.CoveringIndex

class IndexCollectionManagerTest extends HyperspaceSuite {
private val testLogManagerFactory: IndexLogManagerFactory = new IndexLogManagerFactory {
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -28,7 +28,7 @@ import org.apache.spark.sql.types.{StringType, StructField, StructType}

import com.microsoft.hyperspace.{BuildInfo, HyperspaceException, TestUtils}
import com.microsoft.hyperspace.index.IndexConstants.UNKNOWN_FILE_ID
import com.microsoft.hyperspace.index.types.covering.CoveringIndex
import com.microsoft.hyperspace.index.covering.CoveringIndex
import com.microsoft.hyperspace.util.{JsonUtils, PathUtils}

class IndexLogEntryTest extends HyperspaceSuite with SQLHelper {
Expand Down Expand Up @@ -77,7 +77,7 @@ class IndexLogEntryTest extends HyperspaceSuite with SQLHelper {
|{
| "name" : "indexName",
| "derivedDataset" : {
| "type" : "com.microsoft.hyperspace.index.types.covering.CoveringIndex",
| "type" : "com.microsoft.hyperspace.index.covering.CoveringIndex",
| "indexedColumns" : [ "col1" ],
| "includedColumns" : [ "col2", "col3" ],
| "schema" : {
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -25,7 +25,7 @@ import org.apache.spark.sql.types.{IntegerType, StringType, StructField, StructT
import com.microsoft.hyperspace.HyperspaceException
import com.microsoft.hyperspace.TestUtils
import com.microsoft.hyperspace.index.IndexConstants.HYPERSPACE_LOG
import com.microsoft.hyperspace.index.types.covering.CoveringIndex
import com.microsoft.hyperspace.index.covering.CoveringIndex
import com.microsoft.hyperspace.util.{FileUtils, JsonUtils}

class IndexLogManagerImplTest extends HyperspaceSuite {
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -28,7 +28,7 @@ import com.microsoft.hyperspace.{Hyperspace, HyperspaceException, MockEventLogge
import com.microsoft.hyperspace.TestUtils.{copyWithState, getFileIdTracker, latestIndexLogEntry, logManager}
import com.microsoft.hyperspace.actions.Constants
import com.microsoft.hyperspace.index.IndexConstants.{GLOBBING_PATTERN_KEY, OPTIMIZE_FILE_SIZE_THRESHOLD, REFRESH_MODE_FULL, REFRESH_MODE_INCREMENTAL}
import com.microsoft.hyperspace.index.types.covering.CoveringIndex
import com.microsoft.hyperspace.index.covering.CoveringIndex
import com.microsoft.hyperspace.telemetry.OptimizeActionEvent
import com.microsoft.hyperspace.util.{FileUtils, PathUtils}

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -20,7 +20,7 @@ import org.apache.spark.SparkFunSuite
import org.apache.spark.sql.types.{IntegerType, StringType, StructField, StructType}

import com.microsoft.hyperspace.actions.Constants
import com.microsoft.hyperspace.index.types.covering.CoveringIndex
import com.microsoft.hyperspace.index.covering.CoveringIndex

class IndexTest extends SparkFunSuite {
val indexConfig1 = IndexConfig("myIndex1", Array("id"), Seq("name"))
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -24,7 +24,7 @@ import com.microsoft.hyperspace.{Hyperspace, HyperspaceException, MockEventLogge
import com.microsoft.hyperspace.TestUtils.{getFileIdTracker, logManager}
import com.microsoft.hyperspace.actions.{RefreshIncrementalAction, RefreshQuickAction}
import com.microsoft.hyperspace.index.IndexConstants.REFRESH_MODE_INCREMENTAL
import com.microsoft.hyperspace.index.types.covering.CoveringIndex
import com.microsoft.hyperspace.index.covering.CoveringIndex
import com.microsoft.hyperspace.telemetry.RefreshIncrementalActionEvent
import com.microsoft.hyperspace.util.{FileUtils, PathUtils}
import com.microsoft.hyperspace.util.PathUtils.DataPathFilter
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -24,7 +24,7 @@ import com.microsoft.hyperspace.{Hyperspace, HyperspaceException, MockEventLogge
import com.microsoft.hyperspace.TestUtils.{getFileIdTracker, logManager}
import com.microsoft.hyperspace.actions.{RefreshIncrementalAction, RefreshQuickAction}
import com.microsoft.hyperspace.index.IndexConstants.REFRESH_MODE_INCREMENTAL
import com.microsoft.hyperspace.index.types.covering.CoveringIndex
import com.microsoft.hyperspace.index.covering.CoveringIndex
import com.microsoft.hyperspace.telemetry.RefreshIncrementalActionEvent
import com.microsoft.hyperspace.util.{FileUtils, PathUtils}
import com.microsoft.hyperspace.util.PathUtils.DataPathFilter
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,7 @@
* limitations under the License.
*/

package com.microsoft.hyperspace.index.types.covering
package com.microsoft.hyperspace.index.covering

import org.apache.hadoop.conf.Configuration
import org.apache.hadoop.fs.Path
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,7 @@
* limitations under the License.
*/

package com.microsoft.hyperspace.index.types.covering
package com.microsoft.hyperspace.index.covering

import org.apache.hadoop.fs.Path
import org.apache.spark.sql.catalyst.catalog.BucketSpec
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,7 @@
* limitations under the License.
*/

package com.microsoft.hyperspace.index.types.covering
package com.microsoft.hyperspace.index.covering

import org.apache.hadoop.conf.Configuration
import org.apache.hadoop.fs.Path
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,7 @@
* limitations under the License.
*/

package com.microsoft.hyperspace.index.types.covering
package com.microsoft.hyperspace.index.covering

import org.apache.hadoop.fs.Path
import org.apache.spark.sql.Row
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,7 @@
* limitations under the License.
*/

package com.microsoft.hyperspace.index.types.covering
package com.microsoft.hyperspace.index.covering

import org.apache.hadoop.fs.Path
import org.apache.spark.sql.catalyst.catalog.BucketSpec
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -26,7 +26,7 @@ import org.apache.spark.sql.types.{IntegerType, StringType}
import com.microsoft.hyperspace.TestUtils.latestIndexLogEntry
import com.microsoft.hyperspace.actions.Constants
import com.microsoft.hyperspace.index.{HyperspaceRuleSuite, IndexCollectionManager, IndexConfig, IndexConstants, IndexLogEntryTags}
import com.microsoft.hyperspace.index.types.covering.RuleUtils
import com.microsoft.hyperspace.index.covering.RuleUtils
import com.microsoft.hyperspace.util.FileUtils

class CandidateIndexCollectorTest extends HyperspaceRuleSuite with SQLHelper {
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -25,7 +25,7 @@ import org.apache.spark.sql.execution.datasources.{HadoopFsRelation, InMemoryFil
import com.microsoft.hyperspace.{Hyperspace, Implicits, SampleData, TestConfig}
import com.microsoft.hyperspace.actions.Constants
import com.microsoft.hyperspace.index._
import com.microsoft.hyperspace.index.types.covering.{FilterIndexRule, JoinIndexRule}
import com.microsoft.hyperspace.index.covering.{FilterIndexRule, JoinIndexRule}

class ScoreBasedIndexPlanOptimizerTest extends QueryTest with HyperspaceSuite {
private val testDir = inTempDir("scoreBasedIndexPlanOptimizerTest")
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -21,7 +21,7 @@ import org.apache.spark.sql.types.{IntegerType, StringType, StructField, StructT

import com.microsoft.hyperspace.actions.Constants
import com.microsoft.hyperspace.index._
import com.microsoft.hyperspace.index.types.covering.CoveringIndex
import com.microsoft.hyperspace.index.covering.CoveringIndex

class JsonUtilsTest extends SparkFunSuite {
test("Test for JsonUtils.") {
Expand Down

0 comments on commit 7f10ec7

Please sign in to comment.