[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-11-10 Thread asfgit
Github user asfgit closed the pull request at:

https://github.com/apache/spark/pull/8101


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-11-05 Thread JoshRosen
Github user JoshRosen commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-154195973
  
Hi @yjshen,

I've opened #9503 to re-enable these Docker tests.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-10-21 Thread JoshRosen
Github user JoshRosen commented on a diff in the pull request:

https://github.com/apache/spark/pull/8101#discussion_r42677306
  
--- Diff: 
sql/core/src/test/scala/org/apache/spark/sql/jdbc/DockerHacks.scala ---
@@ -0,0 +1,166 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.spark.sql.jdbc
+
+import java.sql.Connection
+
+import scala.collection.JavaConverters._
+import scala.collection.mutable.MutableList
+
+import com.spotify.docker.client.messages.ContainerConfig
+import com.spotify.docker.client._
+
+import org.apache.spark.SparkFunSuite
+import org.apache.spark.sql.test.SharedSQLContext
+import org.scalatest.BeforeAndAfterAll
+
+abstract class DatabaseOnDocker {
+  /**
+   * The docker image to be pulled
+   */
+  def imageName: String
+
+  /**
+   * A Seq of environment variables in the form of VAR=value
+   */
+  def env: Seq[String]
+
+  /**
+   * jdbcUrl should be a lazy val or a function since `ip` it relies on is 
only available after
+   * the docker container starts
+   */
+  def jdbcUrl: String
+
+  private val docker: DockerClient = DockerClientFactory.get()
+  private var containerId: String = null
+
+  lazy val ip = 
docker.inspectContainer(containerId).networkSettings.ipAddress
+
+  def start(): Unit = {
+while (true) {
+  try {
+val config = ContainerConfig.builder()
+  .image(imageName).env(env.asJava)
+  .build()
+containerId = docker.createContainer(config).id
+docker.startContainer(containerId)
+return
+  } catch {
+case e: ImageNotFoundException => retry(5)(docker.pull(imageName))
+  }
+}
+  }
+
+  private def retry[T](n: Int)(fn: => T): T = {
+try {
+  fn
+} catch {
+  case e if n > 1 =>
+retry(n - 1)(fn)
+}
+  }
+
+  def close(): Unit = {
+docker.killContainer(containerId)
+docker.removeContainer(containerId)
+DockerClientFactory.close(docker)
+  }
+}
+
+abstract class DatabaseIntegrationSuite extends SparkFunSuite
+  with BeforeAndAfterAll with SharedSQLContext {
+
+  def db: DatabaseOnDocker
+
+  def waitForDatabase(ip: String, maxMillis: Long) {
+val before = System.currentTimeMillis()
+var lastException: java.sql.SQLException = null
+while (true) {
+  if (System.currentTimeMillis() > before + maxMillis) {
+throw new java.sql.SQLException(s"Database not up after $maxMillis 
ms.", lastException)
+  }
+  try {
+val conn = java.sql.DriverManager.getConnection(db.jdbcUrl)
+conn.close()
+return
+  } catch {
+case e: java.sql.SQLException =>
+  lastException = e
+  java.lang.Thread.sleep(250)
+  }
+}
+  }
+
+  def setupDatabase(ip: String): Unit = {
+val conn: Connection = java.sql.DriverManager.getConnection(db.jdbcUrl)
+try {
+  dataPreparation(conn)
+} finally {
+  conn.close()
+}
+  }
+
+  /**
+   * Prepare databases and tables for testing
+   */
+  def dataPreparation(connection: Connection)
+
+  override def beforeAll() {
+super.beforeAll()
+db.start()
+waitForDatabase(db.ip, 6)
+setupDatabase(db.ip)
+  }
+
+  override def afterAll() {
+try {
+  db.close()
+} finally {
+  super.afterAll()
+}
+  }
+}
+
+/**
+ * A factory and morgue for DockerClient objects.  In the DockerClient we 
use,
+ * calling close() closes the desired DockerClient but also renders all 
other
+ * DockerClients inoperable.  This is inconvenient if we have more than one
+ * open, such as during tests.
+ */
+object DockerClientFactory {
--- End diff --

Hey, so what's the

[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-10-19 Thread lresende
Github user lresende commented on a diff in the pull request:

https://github.com/apache/spark/pull/8101#discussion_r42396001
  
--- Diff: 
sql/core/src/test/scala/org/apache/spark/sql/jdbc/PostgresIntegrationSuite.scala
 ---
@@ -0,0 +1,75 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.spark.sql.jdbc
+
+import java.sql.Connection
+import java.util.Properties
+
+class PostgresIntegrationSuite extends DatabaseIntegrationSuite {
+  val db = new DatabaseOnDocker {
+val imageName = "postgres:latest"
--- End diff --

+1, at least we should keep on the same version of the rdbms in question 
(as sometimes there are tweaks, enhancements on the docker image itself)


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-10-18 Thread JoshRosen
Github user JoshRosen commented on a diff in the pull request:

https://github.com/apache/spark/pull/8101#discussion_r42330567
  
--- Diff: 
sql/core/src/test/scala/org/apache/spark/sql/jdbc/DockerHacks.scala ---
@@ -0,0 +1,166 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.spark.sql.jdbc
+
+import java.sql.Connection
+
+import scala.collection.JavaConverters._
+import scala.collection.mutable.MutableList
+
+import com.spotify.docker.client.messages.ContainerConfig
+import com.spotify.docker.client._
+
+import org.apache.spark.SparkFunSuite
+import org.apache.spark.sql.test.SharedSQLContext
+import org.scalatest.BeforeAndAfterAll
+
+abstract class DatabaseOnDocker {
+  /**
+   * The docker image to be pulled
+   */
+  def imageName: String
+
+  /**
+   * A Seq of environment variables in the form of VAR=value
+   */
+  def env: Seq[String]
+
+  /**
+   * jdbcUrl should be a lazy val or a function since `ip` it relies on is 
only available after
+   * the docker container starts
+   */
+  def jdbcUrl: String
+
+  private val docker: DockerClient = DockerClientFactory.get()
+  private var containerId: String = null
+
+  lazy val ip = 
docker.inspectContainer(containerId).networkSettings.ipAddress
+
+  def start(): Unit = {
+while (true) {
+  try {
+val config = ContainerConfig.builder()
+  .image(imageName).env(env.asJava)
+  .build()
+containerId = docker.createContainer(config).id
+docker.startContainer(containerId)
+return
+  } catch {
+case e: ImageNotFoundException => retry(5)(docker.pull(imageName))
+  }
+}
+  }
+
+  private def retry[T](n: Int)(fn: => T): T = {
+try {
+  fn
+} catch {
+  case e if n > 1 =>
+retry(n - 1)(fn)
+}
+  }
+
+  def close(): Unit = {
+docker.killContainer(containerId)
+docker.removeContainer(containerId)
+DockerClientFactory.close(docker)
+  }
+}
+
+abstract class DatabaseIntegrationSuite extends SparkFunSuite
+  with BeforeAndAfterAll with SharedSQLContext {
+
+  def db: DatabaseOnDocker
+
+  def waitForDatabase(ip: String, maxMillis: Long) {
+val before = System.currentTimeMillis()
+var lastException: java.sql.SQLException = null
+while (true) {
+  if (System.currentTimeMillis() > before + maxMillis) {
+throw new java.sql.SQLException(s"Database not up after $maxMillis 
ms.", lastException)
+  }
+  try {
+val conn = java.sql.DriverManager.getConnection(db.jdbcUrl)
+conn.close()
+return
+  } catch {
+case e: java.sql.SQLException =>
+  lastException = e
+  java.lang.Thread.sleep(250)
+  }
+}
+  }
+
+  def setupDatabase(ip: String): Unit = {
+val conn: Connection = java.sql.DriverManager.getConnection(db.jdbcUrl)
+try {
+  dataPreparation(conn)
+} finally {
+  conn.close()
+}
+  }
+
+  /**
+   * Prepare databases and tables for testing
+   */
+  def dataPreparation(connection: Connection)
+
+  override def beforeAll() {
+super.beforeAll()
+db.start()
+waitForDatabase(db.ip, 6)
+setupDatabase(db.ip)
--- End diff --

Just hit this problem while testing this out locally.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional

[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-10-18 Thread JoshRosen
Github user JoshRosen commented on a diff in the pull request:

https://github.com/apache/spark/pull/8101#discussion_r42330560
  
--- Diff: 
sql/core/src/test/scala/org/apache/spark/sql/jdbc/DockerHacks.scala ---
@@ -0,0 +1,166 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.spark.sql.jdbc
+
+import java.sql.Connection
+
+import scala.collection.JavaConverters._
+import scala.collection.mutable.MutableList
+
+import com.spotify.docker.client.messages.ContainerConfig
+import com.spotify.docker.client._
+
+import org.apache.spark.SparkFunSuite
+import org.apache.spark.sql.test.SharedSQLContext
+import org.scalatest.BeforeAndAfterAll
+
+abstract class DatabaseOnDocker {
+  /**
+   * The docker image to be pulled
+   */
+  def imageName: String
+
+  /**
+   * A Seq of environment variables in the form of VAR=value
+   */
+  def env: Seq[String]
+
+  /**
+   * jdbcUrl should be a lazy val or a function since `ip` it relies on is 
only available after
+   * the docker container starts
+   */
+  def jdbcUrl: String
+
+  private val docker: DockerClient = DockerClientFactory.get()
+  private var containerId: String = null
+
+  lazy val ip = 
docker.inspectContainer(containerId).networkSettings.ipAddress
+
+  def start(): Unit = {
+while (true) {
+  try {
+val config = ContainerConfig.builder()
+  .image(imageName).env(env.asJava)
+  .build()
+containerId = docker.createContainer(config).id
+docker.startContainer(containerId)
+return
+  } catch {
+case e: ImageNotFoundException => retry(5)(docker.pull(imageName))
+  }
+}
+  }
+
+  private def retry[T](n: Int)(fn: => T): T = {
+try {
+  fn
+} catch {
+  case e if n > 1 =>
+retry(n - 1)(fn)
+}
+  }
+
+  def close(): Unit = {
+docker.killContainer(containerId)
+docker.removeContainer(containerId)
+DockerClientFactory.close(docker)
+  }
+}
+
+abstract class DatabaseIntegrationSuite extends SparkFunSuite
+  with BeforeAndAfterAll with SharedSQLContext {
+
+  def db: DatabaseOnDocker
+
+  def waitForDatabase(ip: String, maxMillis: Long) {
+val before = System.currentTimeMillis()
+var lastException: java.sql.SQLException = null
+while (true) {
+  if (System.currentTimeMillis() > before + maxMillis) {
+throw new java.sql.SQLException(s"Database not up after $maxMillis 
ms.", lastException)
+  }
+  try {
+val conn = java.sql.DriverManager.getConnection(db.jdbcUrl)
+conn.close()
+return
+  } catch {
+case e: java.sql.SQLException =>
+  lastException = e
+  java.lang.Thread.sleep(250)
+  }
+}
+  }
+
+  def setupDatabase(ip: String): Unit = {
+val conn: Connection = java.sql.DriverManager.getConnection(db.jdbcUrl)
+try {
+  dataPreparation(conn)
+} finally {
+  conn.close()
+}
+  }
+
+  /**
+   * Prepare databases and tables for testing
+   */
+  def dataPreparation(connection: Connection)
+
+  override def beforeAll() {
+super.beforeAll()
+db.start()
+waitForDatabase(db.ip, 6)
+setupDatabase(db.ip)
--- End diff --

If an exception is thrown here, then I don't think that the Docker 
container will be cleaned up.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews

[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-10-18 Thread JoshRosen
Github user JoshRosen commented on a diff in the pull request:

https://github.com/apache/spark/pull/8101#discussion_r42329989
  
--- Diff: 
sql/core/src/test/scala/org/apache/spark/sql/jdbc/DockerHacks.scala ---
@@ -0,0 +1,166 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.spark.sql.jdbc
+
+import java.sql.Connection
+
+import scala.collection.JavaConverters._
+import scala.collection.mutable.MutableList
+
+import com.spotify.docker.client.messages.ContainerConfig
+import com.spotify.docker.client._
+
+import org.apache.spark.SparkFunSuite
+import org.apache.spark.sql.test.SharedSQLContext
+import org.scalatest.BeforeAndAfterAll
+
+abstract class DatabaseOnDocker {
+  /**
+   * The docker image to be pulled
+   */
+  def imageName: String
+
+  /**
+   * A Seq of environment variables in the form of VAR=value
+   */
+  def env: Seq[String]
+
+  /**
+   * jdbcUrl should be a lazy val or a function since `ip` it relies on is 
only available after
+   * the docker container starts
+   */
+  def jdbcUrl: String
+
+  private val docker: DockerClient = DockerClientFactory.get()
+  private var containerId: String = null
+
+  lazy val ip = 
docker.inspectContainer(containerId).networkSettings.ipAddress
+
+  def start(): Unit = {
+while (true) {
+  try {
+val config = ContainerConfig.builder()
+  .image(imageName).env(env.asJava)
+  .build()
+containerId = docker.createContainer(config).id
+docker.startContainer(containerId)
+return
+  } catch {
+case e: ImageNotFoundException => retry(5)(docker.pull(imageName))
--- End diff --

Also... why not _first_ try to pull the image and only then try to start 
the container?


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-10-18 Thread JoshRosen
Github user JoshRosen commented on a diff in the pull request:

https://github.com/apache/spark/pull/8101#discussion_r42329967
  
--- Diff: 
sql/core/src/test/scala/org/apache/spark/sql/jdbc/DockerHacks.scala ---
@@ -0,0 +1,166 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.spark.sql.jdbc
+
+import java.sql.Connection
+
+import scala.collection.JavaConverters._
+import scala.collection.mutable.MutableList
+
+import com.spotify.docker.client.messages.ContainerConfig
+import com.spotify.docker.client._
+
+import org.apache.spark.SparkFunSuite
+import org.apache.spark.sql.test.SharedSQLContext
+import org.scalatest.BeforeAndAfterAll
+
+abstract class DatabaseOnDocker {
+  /**
+   * The docker image to be pulled
+   */
+  def imageName: String
+
+  /**
+   * A Seq of environment variables in the form of VAR=value
+   */
+  def env: Seq[String]
+
+  /**
+   * jdbcUrl should be a lazy val or a function since `ip` it relies on is 
only available after
+   * the docker container starts
+   */
+  def jdbcUrl: String
+
+  private val docker: DockerClient = DockerClientFactory.get()
+  private var containerId: String = null
+
+  lazy val ip = 
docker.inspectContainer(containerId).networkSettings.ipAddress
+
+  def start(): Unit = {
+while (true) {
+  try {
+val config = ContainerConfig.builder()
+  .image(imageName).env(env.asJava)
+  .build()
+containerId = docker.createContainer(config).id
+docker.startContainer(containerId)
+return
+  } catch {
+case e: ImageNotFoundException => retry(5)(docker.pull(imageName))
--- End diff --

Should log something here, since otherwise it's hard to debug what's 
happening.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-10-16 Thread marmbrus
Github user marmbrus commented on a diff in the pull request:

https://github.com/apache/spark/pull/8101#discussion_r42286254
  
--- Diff: 
sql/core/src/test/scala/org/apache/spark/sql/jdbc/PostgresIntegrationSuite.scala
 ---
@@ -0,0 +1,75 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.spark.sql.jdbc
+
+import java.sql.Connection
+import java.util.Properties
+
+class PostgresIntegrationSuite extends DatabaseIntegrationSuite {
+  val db = new DatabaseOnDocker {
+val imageName = "postgres:latest"
--- End diff --

+1


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-10-16 Thread JoshRosen
Github user JoshRosen commented on a diff in the pull request:

https://github.com/apache/spark/pull/8101#discussion_r42283328
  
--- Diff: 
sql/core/src/test/scala/org/apache/spark/sql/jdbc/PostgresIntegrationSuite.scala
 ---
@@ -0,0 +1,75 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.spark.sql.jdbc
+
+import java.sql.Connection
+import java.util.Properties
+
+class PostgresIntegrationSuite extends DatabaseIntegrationSuite {
+  val db = new DatabaseOnDocker {
+val imageName = "postgres:latest"
--- End diff --

One concern: this has the potential to become flaky if the image is 
updated. I'd prefer to freeze a particular version here, for the same reason 
that I like things like Maven and `pip --freeze`.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-30 Thread JoshRosen
Github user JoshRosen commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-144578314
  
I'd like to help get this patch merged so that we can re-run these tests, 
but before we put a lot more work into polishing it I would like to figure out 
whether our regular Jenkins build is the right place to run these tests.

These tests are fairly heavyweight to run (since they have to download a 
bunch of Docker images) and might add significant amounts of time to the test 
runs. Therefore, I think we should skip them for the majority of pull requests 
and should only run them when JDBC-related code is changed (maybe just code 
under the `jdbc/` directory).

Similarly, we may not want to run these tests as part of every master 
build. Over time, I imagine that we'll accumulate larger-and-larger regression 
test suites here and they're going to add a huge cost for most builds. 
Therefore, I think that we should try to tag these suites so that they're not 
run as part of most master builds but are only run once per day or something 
like that.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread yjshen
Github user yjshen commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140396062
  
It seems when test build triggered for multiple times in a row, only the 
first test build would fail and all subsequent builds success.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140346653
  
Test PASSed.
Refer to this link for build results (access rights to CI server needed): 
https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42480/
Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140346649
  
Merged build finished. Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140346371
  
  [Test build #42480 has 
finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42480/console)
 for   PR 8101 at commit 
[`fbc471b`](https://github.com/apache/spark/commit/fbc471bd8de9d7742b4329f79610ab9dd8fe123c).
 * This patch **passes all tests**.
 * This patch merges cleanly.
 * This patch adds the following public classes _(experimental)_:
  * `abstract class DatabaseOnDocker `
  * `class MySQLIntegrationSuite extends DatabaseIntegrationSuite `
  * `assert(types(0).equals("class java.lang.Integer"))`
  * `assert(types(1).equals("class java.lang.String"))`
  * `assert(types(0).equals("class java.lang.Boolean"))`
  * `assert(types(1).equals("class java.lang.Long"))`
  * `assert(types(2).equals("class java.lang.Integer"))`
  * `assert(types(3).equals("class java.lang.Integer"))`
  * `assert(types(4).equals("class java.lang.Integer"))`
  * `assert(types(5).equals("class java.lang.Long"))`
  * `assert(types(6).equals("class java.math.BigDecimal"))`
  * `assert(types(7).equals("class java.lang.Double"))`
  * `assert(types(8).equals("class java.lang.Double"))`
  * `assert(types(0).equals("class java.sql.Date"))`
  * `assert(types(1).equals("class java.sql.Timestamp"))`
  * `assert(types(2).equals("class java.sql.Timestamp"))`
  * `assert(types(3).equals("class java.sql.Timestamp"))`
  * `assert(types(4).equals("class java.sql.Date"))`
  * `assert(types(0).equals("class java.lang.String"))`
  * `assert(types(1).equals("class java.lang.String"))`
  * `assert(types(2).equals("class java.lang.String"))`
  * `assert(types(3).equals("class java.lang.String"))`
  * `assert(types(4).equals("class java.lang.String"))`
  * `assert(types(5).equals("class java.lang.String"))`
  * `assert(types(6).equals("class [B"))`
  * `assert(types(7).equals("class [B"))`
  * `assert(types(8).equals("class [B"))`
  * `class PostgresIntegrationSuite extends DatabaseIntegrationSuite `
  * `assert(types(0).equals("class java.lang.String"))`
  * `assert(types(1).equals("class java.lang.Integer"))`
  * `assert(types(2).equals("class java.lang.Double"))`
  * `assert(types(3).equals("class java.lang.Long"))`
  * `assert(types(4).equals("class java.lang.Boolean"))`
  * `assert(types(5).equals("class [B"))`
  * `assert(types(6).equals("class [B"))`
  * `assert(types(7).equals("class java.lang.Boolean"))`
  * `assert(types(8).equals("class java.lang.String"))`
  * `assert(types(9).equals("class java.lang.String"))`



---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140336023
  
Test PASSed.
Refer to this link for build results (access rights to CI server needed): 
https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42474/
Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140336020
  
Merged build finished. Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140335894
  
  [Test build #42474 has 
finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42474/console)
 for   PR 8101 at commit 
[`fbc471b`](https://github.com/apache/spark/commit/fbc471bd8de9d7742b4329f79610ab9dd8fe123c).
 * This patch **passes all tests**.
 * This patch merges cleanly.
 * This patch adds the following public classes _(experimental)_:
  * `abstract class DatabaseOnDocker `
  * `class MySQLIntegrationSuite extends DatabaseIntegrationSuite `
  * `assert(types(0).equals("class java.lang.Integer"))`
  * `assert(types(1).equals("class java.lang.String"))`
  * `assert(types(0).equals("class java.lang.Boolean"))`
  * `assert(types(1).equals("class java.lang.Long"))`
  * `assert(types(2).equals("class java.lang.Integer"))`
  * `assert(types(3).equals("class java.lang.Integer"))`
  * `assert(types(4).equals("class java.lang.Integer"))`
  * `assert(types(5).equals("class java.lang.Long"))`
  * `assert(types(6).equals("class java.math.BigDecimal"))`
  * `assert(types(7).equals("class java.lang.Double"))`
  * `assert(types(8).equals("class java.lang.Double"))`
  * `assert(types(0).equals("class java.sql.Date"))`
  * `assert(types(1).equals("class java.sql.Timestamp"))`
  * `assert(types(2).equals("class java.sql.Timestamp"))`
  * `assert(types(3).equals("class java.sql.Timestamp"))`
  * `assert(types(4).equals("class java.sql.Date"))`
  * `assert(types(0).equals("class java.lang.String"))`
  * `assert(types(1).equals("class java.lang.String"))`
  * `assert(types(2).equals("class java.lang.String"))`
  * `assert(types(3).equals("class java.lang.String"))`
  * `assert(types(4).equals("class java.lang.String"))`
  * `assert(types(5).equals("class java.lang.String"))`
  * `assert(types(6).equals("class [B"))`
  * `assert(types(7).equals("class [B"))`
  * `assert(types(8).equals("class [B"))`
  * `class PostgresIntegrationSuite extends DatabaseIntegrationSuite `
  * `assert(types(0).equals("class java.lang.String"))`
  * `assert(types(1).equals("class java.lang.Integer"))`
  * `assert(types(2).equals("class java.lang.Double"))`
  * `assert(types(3).equals("class java.lang.Long"))`
  * `assert(types(4).equals("class java.lang.Boolean"))`
  * `assert(types(5).equals("class [B"))`
  * `assert(types(6).equals("class [B"))`
  * `assert(types(7).equals("class java.lang.Boolean"))`
  * `assert(types(8).equals("class java.lang.String"))`
  * `assert(types(9).equals("class java.lang.String"))`



---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140334769
  
Test PASSed.
Refer to this link for build results (access rights to CI server needed): 
https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42473/
Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140334768
  
Merged build finished. Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140334623
  
  [Test build #42473 has 
finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42473/console)
 for   PR 8101 at commit 
[`fbc471b`](https://github.com/apache/spark/commit/fbc471bd8de9d7742b4329f79610ab9dd8fe123c).
 * This patch **passes all tests**.
 * This patch merges cleanly.
 * This patch adds the following public classes _(experimental)_:
  * `abstract class DatabaseOnDocker `
  * `class MySQLIntegrationSuite extends DatabaseIntegrationSuite `
  * `assert(types(0).equals("class java.lang.Integer"))`
  * `assert(types(1).equals("class java.lang.String"))`
  * `assert(types(0).equals("class java.lang.Boolean"))`
  * `assert(types(1).equals("class java.lang.Long"))`
  * `assert(types(2).equals("class java.lang.Integer"))`
  * `assert(types(3).equals("class java.lang.Integer"))`
  * `assert(types(4).equals("class java.lang.Integer"))`
  * `assert(types(5).equals("class java.lang.Long"))`
  * `assert(types(6).equals("class java.math.BigDecimal"))`
  * `assert(types(7).equals("class java.lang.Double"))`
  * `assert(types(8).equals("class java.lang.Double"))`
  * `assert(types(0).equals("class java.sql.Date"))`
  * `assert(types(1).equals("class java.sql.Timestamp"))`
  * `assert(types(2).equals("class java.sql.Timestamp"))`
  * `assert(types(3).equals("class java.sql.Timestamp"))`
  * `assert(types(4).equals("class java.sql.Date"))`
  * `assert(types(0).equals("class java.lang.String"))`
  * `assert(types(1).equals("class java.lang.String"))`
  * `assert(types(2).equals("class java.lang.String"))`
  * `assert(types(3).equals("class java.lang.String"))`
  * `assert(types(4).equals("class java.lang.String"))`
  * `assert(types(5).equals("class java.lang.String"))`
  * `assert(types(6).equals("class [B"))`
  * `assert(types(7).equals("class [B"))`
  * `assert(types(8).equals("class [B"))`
  * `class PostgresIntegrationSuite extends DatabaseIntegrationSuite `
  * `assert(types(0).equals("class java.lang.String"))`
  * `assert(types(1).equals("class java.lang.Integer"))`
  * `assert(types(2).equals("class java.lang.Double"))`
  * `assert(types(3).equals("class java.lang.Long"))`
  * `assert(types(4).equals("class java.lang.Boolean"))`
  * `assert(types(5).equals("class [B"))`
  * `assert(types(6).equals("class [B"))`
  * `assert(types(7).equals("class java.lang.Boolean"))`
  * `assert(types(8).equals("class java.lang.String"))`
  * `assert(types(9).equals("class java.lang.String"))`



---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140321433
  
Merged build finished. Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140321369
  
  [Test build #42476 has 
finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42476/console)
 for   PR 8101 at commit 
[`fbc471b`](https://github.com/apache/spark/commit/fbc471bd8de9d7742b4329f79610ab9dd8fe123c).
 * This patch **fails Spark unit tests**.
 * This patch merges cleanly.
 * This patch adds the following public classes _(experimental)_:
  * `abstract class DatabaseOnDocker `
  * `class MySQLIntegrationSuite extends DatabaseIntegrationSuite `
  * `assert(types(0).equals("class java.lang.Integer"))`
  * `assert(types(1).equals("class java.lang.String"))`
  * `assert(types(0).equals("class java.lang.Boolean"))`
  * `assert(types(1).equals("class java.lang.Long"))`
  * `assert(types(2).equals("class java.lang.Integer"))`
  * `assert(types(3).equals("class java.lang.Integer"))`
  * `assert(types(4).equals("class java.lang.Integer"))`
  * `assert(types(5).equals("class java.lang.Long"))`
  * `assert(types(6).equals("class java.math.BigDecimal"))`
  * `assert(types(7).equals("class java.lang.Double"))`
  * `assert(types(8).equals("class java.lang.Double"))`
  * `assert(types(0).equals("class java.sql.Date"))`
  * `assert(types(1).equals("class java.sql.Timestamp"))`
  * `assert(types(2).equals("class java.sql.Timestamp"))`
  * `assert(types(3).equals("class java.sql.Timestamp"))`
  * `assert(types(4).equals("class java.sql.Date"))`
  * `assert(types(0).equals("class java.lang.String"))`
  * `assert(types(1).equals("class java.lang.String"))`
  * `assert(types(2).equals("class java.lang.String"))`
  * `assert(types(3).equals("class java.lang.String"))`
  * `assert(types(4).equals("class java.lang.String"))`
  * `assert(types(5).equals("class java.lang.String"))`
  * `assert(types(6).equals("class [B"))`
  * `assert(types(7).equals("class [B"))`
  * `assert(types(8).equals("class [B"))`
  * `class PostgresIntegrationSuite extends DatabaseIntegrationSuite `
  * `assert(types(0).equals("class java.lang.String"))`
  * `assert(types(1).equals("class java.lang.Integer"))`
  * `assert(types(2).equals("class java.lang.Double"))`
  * `assert(types(3).equals("class java.lang.Long"))`
  * `assert(types(4).equals("class java.lang.Boolean"))`
  * `assert(types(5).equals("class [B"))`
  * `assert(types(6).equals("class [B"))`
  * `assert(types(7).equals("class java.lang.Boolean"))`
  * `assert(types(8).equals("class java.lang.String"))`
  * `assert(types(9).equals("class java.lang.String"))`



---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140321435
  
Test FAILed.
Refer to this link for build results (access rights to CI server needed): 
https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42476/
Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140319501
  
  [Test build #42480 has 
started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42480/consoleFull)
 for   PR 8101 at commit 
[`fbc471b`](https://github.com/apache/spark/commit/fbc471bd8de9d7742b4329f79610ab9dd8fe123c).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140319150
  
 Merged build triggered.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140319175
  
Merged build started.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread yjshen
Github user yjshen commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140318454
  
Jenkins, retest this please.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140316430
  
  [Test build #42476 has 
started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42476/consoleFull)
 for   PR 8101 at commit 
[`fbc471b`](https://github.com/apache/spark/commit/fbc471bd8de9d7742b4329f79610ab9dd8fe123c).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140315318
  
Merged build started.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140315305
  
 Merged build triggered.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread yjshen
Github user yjshen commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140315135
  
Jenkins, retest this please.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140307899
  
  [Test build #42474 has 
started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42474/consoleFull)
 for   PR 8101 at commit 
[`fbc471b`](https://github.com/apache/spark/commit/fbc471bd8de9d7742b4329f79610ab9dd8fe123c).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140307135
  
 Merged build triggered.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140307202
  
Merged build started.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread yjshen
Github user yjshen commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140306774
  
Jenkins, retest this please.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140304247
  
  [Test build #42473 has 
started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42473/consoleFull)
 for   PR 8101 at commit 
[`fbc471b`](https://github.com/apache/spark/commit/fbc471bd8de9d7742b4329f79610ab9dd8fe123c).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140304055
  
Merged build started.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140304040
  
 Merged build triggered.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread yjshen
Github user yjshen commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140303172
  
Jenkins, retest this please.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread yjshen
Github user yjshen commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140303230
  
Jenkins, retest this please.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread yjshen
Github user yjshen commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140303129
  
I'll trigger more test build now.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread yjshen
Github user yjshen commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140303246
  
Jenkins, retest this please.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-15 Thread yjshen
Github user yjshen commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-140302922
  
After exploring all the build failure above, Mysql test only fails with 
`Image pull failed`, Postgres test would fail due to `create container` or 
`pull image`.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-08 Thread yjshen
Github user yjshen commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-138497422
  
Sorry for my late reply.
MySQLIntegrationSuite would fail with:
```
Error Message

Image pull failed: mysql:latest: ProgressMessage{id=null, status=null, 
stream=null, error=Error pulling image (latest) from mysql, Driver devicemapper 
failed to create image rootfs 
9d3ceacde91b4c7d6c1275032adb558d668afd5489c007f3512b39793ddf992d: Error running 
DeviceCreate (createSnapDevice) dm_task_run failed, progress=null, 
progressDetail=null}
Stacktrace

sbt.ForkMain$ForkError: Image pull failed: mysql:latest: 
ProgressMessage{id=null, status=null, stream=null, error=Error pulling image 
(latest) from mysql, Driver devicemapper failed to create image rootfs 
9d3ceacde91b4c7d6c1275032adb558d668afd5489c007f3512b39793ddf992d: Error running 
DeviceCreate (createSnapDevice) dm_task_run failed, progress=null, 
progressDetail=null}
at 
com.spotify.docker.client.LoggingPullHandler.progress(LoggingPullHandler.java:45)
...
```

PostgresIntegrationSuite would fail with:
```
Error Message

Request error: POST unix://localhost:80/v1.12/containers/create: 500
Stacktrace

sbt.ForkMain$ForkError: Request error: POST 
unix://localhost:80/v1.12/containers/create: 500
at 
com.spotify.docker.client.DefaultDockerClient.propagate(DefaultDockerClient.java:907)
...
```


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-03 Thread marmbrus
Github user marmbrus commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-137595964
  
Where are the errors with pulling the image?  
`com.spotify.docker.client.DockerRequestException: Request error: POST 
unix://localhost:80/v1.12/containers/create: 500` usually indicates a port 
conflict, not a problem pulling the image.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-03 Thread rxin
Github user rxin commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-137595562
  
cc @marmbrus what do you think? Is there a way we can preload the images on 
Jenkins?


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread yjshen
Github user yjshen commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-137017268
  
Pull mysql image would sometimes fail even with 5 retry...


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-137003335
  
Merged build finished. Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-137003339
  
Test PASSed.
Refer to this link for build results (access rights to CI server needed): 
https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/41926/
Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-137003004
  
  [Test build #41926 has 
finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/41926/console)
 for   PR 8101 at commit 
[`fbc471b`](https://github.com/apache/spark/commit/fbc471bd8de9d7742b4329f79610ab9dd8fe123c).
 * This patch **passes all tests**.
 * This patch merges cleanly.
 * This patch adds the following public classes _(experimental)_:
  * `class DCT(JavaTransformer, HasInputCol, HasOutputCol):`
  * `class SQLTransformer(JavaTransformer):`
  * `class StopWordsRemover(JavaTransformer, HasInputCol, HasOutputCol):`



---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-137001104
  
Merged build finished. Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-137001108
  
Test PASSed.
Refer to this link for build results (access rights to CI server needed): 
https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/41921/
Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-137000735
  
  [Test build #41921 has 
finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/41921/console)
 for   PR 8101 at commit 
[`fbc471b`](https://github.com/apache/spark/commit/fbc471bd8de9d7742b4329f79610ab9dd8fe123c).
 * This patch **passes all tests**.
 * This patch merges cleanly.
 * This patch adds the following public classes _(experimental)_:
  * `abstract class DatabaseOnDocker `
  * `class MySQLIntegrationSuite extends DatabaseIntegrationSuite `
  * `assert(types(0).equals("class java.lang.Integer"))`
  * `assert(types(1).equals("class java.lang.String"))`
  * `assert(types(0).equals("class java.lang.Boolean"))`
  * `assert(types(1).equals("class java.lang.Long"))`
  * `assert(types(2).equals("class java.lang.Integer"))`
  * `assert(types(3).equals("class java.lang.Integer"))`
  * `assert(types(4).equals("class java.lang.Integer"))`
  * `assert(types(5).equals("class java.lang.Long"))`
  * `assert(types(6).equals("class java.math.BigDecimal"))`
  * `assert(types(7).equals("class java.lang.Double"))`
  * `assert(types(8).equals("class java.lang.Double"))`
  * `assert(types(0).equals("class java.sql.Date"))`
  * `assert(types(1).equals("class java.sql.Timestamp"))`
  * `assert(types(2).equals("class java.sql.Timestamp"))`
  * `assert(types(3).equals("class java.sql.Timestamp"))`
  * `assert(types(4).equals("class java.sql.Date"))`
  * `assert(types(0).equals("class java.lang.String"))`
  * `assert(types(1).equals("class java.lang.String"))`
  * `assert(types(2).equals("class java.lang.String"))`
  * `assert(types(3).equals("class java.lang.String"))`
  * `assert(types(4).equals("class java.lang.String"))`
  * `assert(types(5).equals("class java.lang.String"))`
  * `assert(types(6).equals("class [B"))`
  * `assert(types(7).equals("class [B"))`
  * `assert(types(8).equals("class [B"))`
  * `class PostgresIntegrationSuite extends DatabaseIntegrationSuite `
  * `assert(types(0).equals("class java.lang.String"))`
  * `assert(types(1).equals("class java.lang.Integer"))`
  * `assert(types(2).equals("class java.lang.Double"))`
  * `assert(types(3).equals("class java.lang.Long"))`
  * `assert(types(4).equals("class java.lang.Boolean"))`
  * `assert(types(5).equals("class [B"))`
  * `assert(types(6).equals("class [B"))`
  * `assert(types(7).equals("class java.lang.Boolean"))`
  * `assert(types(8).equals("class java.lang.String"))`
  * `assert(types(9).equals("class java.lang.String"))`



---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136999422
  
Test PASSed.
Refer to this link for build results (access rights to CI server needed): 
https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/41923/
Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136999419
  
Merged build finished. Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136998934
  
  [Test build #41923 has 
finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/41923/console)
 for   PR 8101 at commit 
[`fbc471b`](https://github.com/apache/spark/commit/fbc471bd8de9d7742b4329f79610ab9dd8fe123c).
 * This patch **passes all tests**.
 * This patch merges cleanly.
 * This patch adds the following public classes _(experimental)_:
  * `class DCT(JavaTransformer, HasInputCol, HasOutputCol):`
  * `class SQLTransformer(JavaTransformer):`
  * `class StopWordsRemover(JavaTransformer, HasInputCol, HasOutputCol):`
  * `case class LimitNode(limit: Int, child: LocalNode) extends 
UnaryLocalNode `
  * `case class UnionNode(children: Seq[LocalNode]) extends LocalNode `



---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136970758
  
  [Test build #41925 has 
finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/41925/console)
 for   PR 8101 at commit 
[`fbc471b`](https://github.com/apache/spark/commit/fbc471bd8de9d7742b4329f79610ab9dd8fe123c).
 * This patch **fails Spark unit tests**.
 * This patch merges cleanly.
 * This patch adds no public classes.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136970794
  
Test FAILed.
Refer to this link for build results (access rights to CI server needed): 
https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/41925/
Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136970793
  
Merged build finished. Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136966769
  
  [Test build #41926 has 
started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/41926/consoleFull)
 for   PR 8101 at commit 
[`fbc471b`](https://github.com/apache/spark/commit/fbc471bd8de9d7742b4329f79610ab9dd8fe123c).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136966047
  
Merged build started.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136965989
  
 Merged build triggered.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136964746
  
  [Test build #41925 has 
started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/41925/consoleFull)
 for   PR 8101 at commit 
[`fbc471b`](https://github.com/apache/spark/commit/fbc471bd8de9d7742b4329f79610ab9dd8fe123c).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread yjshen
Github user yjshen commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136964226
  
Jenkins, retest this please.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136963567
  
 Merged build triggered.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread yjshen
Github user yjshen commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136963840
  
I'd like to trigger the build multiple times to make sure it works.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136963598
  
Merged build started.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136963463
  
  [Test build #41923 has 
started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/41923/consoleFull)
 for   PR 8101 at commit 
[`fbc471b`](https://github.com/apache/spark/commit/fbc471bd8de9d7742b4329f79610ab9dd8fe123c).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136962547
  
 Merged build triggered.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136962562
  
Merged build started.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread yjshen
Github user yjshen commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136962566
  
Jenkins, retest this please.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread yjshen
Github user yjshen commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136962226
  
Jenkins, retest this please.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread yjshen
Github user yjshen commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136962036
  
Jenkins, retest this please.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136961365
  
Merged build finished. Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136961367
  
Test PASSed.
Refer to this link for build results (access rights to CI server needed): 
https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/41913/
Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136961266
  
  [Test build #41913 has 
finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/41913/console)
 for   PR 8101 at commit 
[`fbc471b`](https://github.com/apache/spark/commit/fbc471bd8de9d7742b4329f79610ab9dd8fe123c).
 * This patch **passes all tests**.
 * This patch merges cleanly.
 * This patch adds no public classes.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136961117
  
  [Test build #41921 has 
started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/41921/consoleFull)
 for   PR 8101 at commit 
[`fbc471b`](https://github.com/apache/spark/commit/fbc471bd8de9d7742b4329f79610ab9dd8fe123c).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136960174
  
 Merged build triggered.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136960195
  
Merged build started.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-02 Thread yjshen
Github user yjshen commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136959971
  
Jenkins, retest this please.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-01 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136937602
  
  [Test build #41913 has 
started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/41913/consoleFull)
 for   PR 8101 at commit 
[`fbc471b`](https://github.com/apache/spark/commit/fbc471bd8de9d7742b4329f79610ab9dd8fe123c).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-01 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136936960
  
 Merged build triggered.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-01 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136936968
  
Merged build started.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-01 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136928983
  
Test PASSed.
Refer to this link for build results (access rights to CI server needed): 
https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/41903/
Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-01 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136928977
  
Merged build finished. Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-01 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136928856
  
  [Test build #41903 has 
finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/41903/console)
 for   PR 8101 at commit 
[`de10e94`](https://github.com/apache/spark/commit/de10e94c0b22194cdb648d279945db8f583bcb69).
 * This patch **passes all tests**.
 * This patch merges cleanly.
 * This patch adds no public classes.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-01 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136912637
  
  [Test build #41903 has 
started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/41903/consoleFull)
 for   PR 8101 at commit 
[`de10e94`](https://github.com/apache/spark/commit/de10e94c0b22194cdb648d279945db8f583bcb69).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-01 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136912033
  
Merged build started.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-01 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136912024
  
 Merged build triggered.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-09-01 Thread yjshen
Github user yjshen commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-136911936
  
Jenkins, retest this please.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-08-24 Thread rxin
Github user rxin commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-134487700
  
Jenkins, test this please.



---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-08-15 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-131387818
  
Test FAILed.
Refer to this link for build results (access rights to CI server needed): 
https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/40963/
Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-08-15 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-131387816
  
Merged build finished. Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-08-15 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-131387806
  
  [Test build #40963 has 
finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/40963/console)
 for   PR 8101 at commit 
[`de10e94`](https://github.com/apache/spark/commit/de10e94c0b22194cdb648d279945db8f583bcb69).
 * This patch **fails Spark unit tests**.
 * This patch merges cleanly.
 * This patch adds no public classes.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-08-15 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-131386456
  
Merged build finished. Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-08-15 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-131386458
  
Test FAILed.
Refer to this link for build results (access rights to CI server needed): 
https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/40961/
Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-08-15 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-131386395
  
  [Test build #40961 has 
finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/40961/console)
 for   PR 8101 at commit 
[`de10e94`](https://github.com/apache/spark/commit/de10e94c0b22194cdb648d279945db8f583bcb69).
 * This patch **fails Spark unit tests**.
 * This patch merges cleanly.
 * This patch adds no public classes.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-08-15 Thread SparkQA
Github user SparkQA commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-131384683
  
  [Test build #40963 has 
started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/40963/consoleFull)
 for   PR 8101 at commit 
[`de10e94`](https://github.com/apache/spark/commit/de10e94c0b22194cdb648d279945db8f583bcb69).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



[GitHub] spark pull request: [SPARK-9818][SQL][WIP]Revert SPARK-6136 to ena...

2015-08-15 Thread AmplabJenkins
Github user AmplabJenkins commented on the pull request:

https://github.com/apache/spark/pull/8101#issuecomment-131384601
  
Merged build started.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastruct...@apache.org or file a JIRA ticket
with INFRA.
---

-
To unsubscribe, e-mail: reviews-unsubscr...@spark.apache.org
For additional commands, e-mail: reviews-h...@spark.apache.org



  1   2   3   >