org.apache.spark.sql.streaming.OutputMode Java Examples
The following examples show how to use
org.apache.spark.sql.streaming.OutputMode.
You can vote up the ones you like or vote down the ones you don't like,
and go to the original project or source file by following the links above each example. You may check out the related API usage on the sidebar.
Example #1
Source File: IcebergSource.java From iceberg with Apache License 2.0 | 6 votes |
@Override public StreamWriter createStreamWriter(String runId, StructType dsStruct, OutputMode mode, DataSourceOptions options) { Preconditions.checkArgument( mode == OutputMode.Append() || mode == OutputMode.Complete(), "Output mode %s is not supported", mode); Configuration conf = new Configuration(lazyBaseConf()); Table table = getTableAndResolveHadoopConfiguration(options, conf); Schema writeSchema = SparkSchemaUtil.convert(table.schema(), dsStruct); TypeUtil.validateWriteSchema(table.schema(), writeSchema, checkNullability(options), checkOrdering(options)); SparkUtil.validatePartitionTransforms(table.spec()); // Spark 2.4.x passes runId to createStreamWriter instead of real queryId, // so we fetch it directly from sparkContext to make writes idempotent String queryId = lazySparkSession().sparkContext().getLocalProperty(StreamExecution.QUERY_ID_KEY()); String appId = lazySparkSession().sparkContext().applicationId(); Broadcast<FileIO> io = lazySparkContext().broadcast(SparkUtil.serializableFileIO(table)); Broadcast<EncryptionManager> encryptionManager = lazySparkContext().broadcast(table.encryption()); return new StreamingWriter(table, io, encryptionManager, options, queryId, mode, appId, writeSchema, dsStruct); }
Example #2
Source File: StreamingWriter.java From iceberg with Apache License 2.0 | 5 votes |
StreamingWriter(Table table, Broadcast<FileIO> io, Broadcast<EncryptionManager> encryptionManager, DataSourceOptions options, String queryId, OutputMode mode, String applicationId, Schema writeSchema, StructType dsSchema) { super(table, io, encryptionManager, options, false, applicationId, writeSchema, dsSchema); this.queryId = queryId; this.mode = mode; }
Example #3
Source File: StructuredStreamingSqlAnalyse.java From sylph with Apache License 2.0 | 5 votes |
@Override public void selectQuery(SelectQuery statement) throws Exception { Dataset<Row> df = sparkSession.sql(statement.toString()); DataStreamWriter<Row> writer = df.writeStream() .foreach(new ConsoleWriter()) .trigger(Trigger.Continuous("90 seconds")) //.option("checkpointLocation", checkpointLocation) .outputMode(OutputMode.Append()); if (!isCompile) { writer.start(); } }
Example #4
Source File: HoodieJavaStreamingApp.java From hudi with Apache License 2.0 | 5 votes |
/** * Hoodie spark streaming job. * * @param streamingInput * @throws Exception */ public void stream(Dataset<Row> streamingInput) throws Exception { DataStreamWriter<Row> writer = streamingInput.writeStream().format("org.apache.hudi") .option("hoodie.insert.shuffle.parallelism", "2").option("hoodie.upsert.shuffle.parallelism", "2") .option(DataSourceWriteOptions.TABLE_TYPE_OPT_KEY(), tableType) .option(DataSourceWriteOptions.RECORDKEY_FIELD_OPT_KEY(), "_row_key") .option(DataSourceWriteOptions.PARTITIONPATH_FIELD_OPT_KEY(), "partition") .option(DataSourceWriteOptions.PRECOMBINE_FIELD_OPT_KEY(), "timestamp") .option(HoodieWriteConfig.TABLE_NAME, tableName).option("checkpointLocation", streamingCheckpointingPath) .outputMode(OutputMode.Append()); updateHiveSyncConfig(writer); writer.trigger(new ProcessingTime(500)).start(tablePath).awaitTermination(streamingDurationInMs); }
Example #5
Source File: ReadLinesFromMultipleFileStreams.java From net.jgp.labs.spark with Apache License 2.0 | 5 votes |
private void start() throws TimeoutException { log.debug("-> start()"); SparkSession spark = SparkSession.builder() .appName("Read lines over a file stream").master("local") .getOrCreate(); Dataset<Row> df = spark .readStream() .format("text") .load(StreamingUtils.getInputDirectory()); StreamingQuery query = df .writeStream() .outputMode(OutputMode.Update()) .format("console").start(); try { query.awaitTermination(); } catch (StreamingQueryException e) { log.error("Exception while waiting for query to end {}.", e .getMessage(), e); } // In this case everything is a string df.show(); df.printSchema(); }
Example #6
Source File: ReadLinesFromFileStream.java From net.jgp.labs.spark with Apache License 2.0 | 5 votes |
private void start() throws TimeoutException { log.debug("-> start()"); SparkSession spark = SparkSession.builder() .appName("Read lines over a file stream") .master("local") .getOrCreate(); Dataset<Row> df = spark .readStream() .format("text") .load(StreamingUtils.getInputDirectory()); StreamingQuery query = df .writeStream() .outputMode(OutputMode.Update()) .format("console") .start(); try { query.awaitTermination(); } catch (StreamingQueryException e) { log.error( "Exception while waiting for query to end {}.", e.getMessage(), e); } // Never executed df.show(); df.printSchema(); }
Example #7
Source File: HiveStreamingDataSource.java From spark-llap with Apache License 2.0 | 4 votes |
@Override public StreamWriter createStreamWriter(final String queryId, final StructType schema, final OutputMode mode, final DataSourceOptions options) { return createDataSourceWriter(queryId, schema, options); }