Packages

c

org.apache.spark.sql.execution.streaming

DistributedHTTPSourceProvider

class DistributedHTTPSourceProvider extends StreamSourceProvider with DataSourceRegister with Logging

Linear Supertypes
Logging, DataSourceRegister, StreamSourceProvider, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. DistributedHTTPSourceProvider
  2. Logging
  3. DataSourceRegister
  4. StreamSourceProvider
  5. AnyRef
  6. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new DistributedHTTPSourceProvider()

Value Members

  1. def createSource(sqlContext: SQLContext, metadataPath: String, schema: Option[StructType], providerName: String, parameters: Map[String, String]): Source
    Definition Classes
    DistributedHTTPSourceProvider → StreamSourceProvider
  2. def shortName(): String

    String that represents the format that this data source provider uses.

    String that represents the format that this data source provider uses.

    Definition Classes
    DistributedHTTPSourceProvider → DataSourceRegister
  3. def sourceSchema(sqlContext: SQLContext, schema: Option[StructType], providerName: String, parameters: Map[String, String]): (String, StructType)

    Returns the name and schema of the source that can be used to continually read data.

    Returns the name and schema of the source that can be used to continually read data.

    Definition Classes
    DistributedHTTPSourceProvider → StreamSourceProvider