Skip to content

Commit 3628af8

Browse files
committed
Addressed more comments
1 parent 34449e4 commit 3628af8

File tree

4 files changed

+3
-3
lines changed

4 files changed

+3
-3
lines changed

sql/core/src/main/scala/org/apache/spark/sql/execution/objects.scala

Lines changed: 1 addition & 0 deletions
Original file line numberDiff line numberDiff line change
@@ -31,6 +31,7 @@ import org.apache.spark.sql.catalyst.expressions.objects.Invoke
3131
import org.apache.spark.sql.catalyst.plans.physical._
3232
import org.apache.spark.sql.Row
3333
import org.apache.spark.sql.catalyst.plans.logical.LogicalKeyedState
34+
import org.apache.spark.sql.execution.streaming.KeyedStateImpl
3435
import org.apache.spark.sql.types.{DataType, ObjectType, StructType}
3536

3637

sql/core/src/main/scala/org/apache/spark/sql/execution/KeyedStateImpl.scala renamed to sql/core/src/main/scala/org/apache/spark/sql/execution/streaming/KeyedStateImpl.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -15,7 +15,7 @@
1515
* limitations under the License.
1616
*/
1717

18-
package org.apache.spark.sql.execution
18+
package org.apache.spark.sql.execution.streaming
1919

2020
import org.apache.spark.sql.KeyedState
2121

sql/core/src/main/scala/org/apache/spark/sql/execution/streaming/StatefulAggregate.scala renamed to sql/core/src/main/scala/org/apache/spark/sql/execution/streaming/statefulOperators.scala

File renamed without changes.

sql/core/src/test/scala/org/apache/spark/sql/streaming/MapGroupsWithStateSuite.scala

Lines changed: 1 addition & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -22,8 +22,7 @@ import org.scalatest.BeforeAndAfterAll
2222
import org.apache.spark.SparkException
2323
import org.apache.spark.sql.KeyedState
2424
import org.apache.spark.sql.catalyst.streaming.InternalOutputModes._
25-
import org.apache.spark.sql.execution.KeyedStateImpl
26-
import org.apache.spark.sql.execution.streaming.MemoryStream
25+
import org.apache.spark.sql.execution.streaming.{KeyedStateImpl, MemoryStream}
2726
import org.apache.spark.sql.execution.streaming.state.StateStore
2827

2928
/** Class to check custom state types */

0 commit comments

Comments
 (0)