| 
 | ||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||
| Uses of Context in org.apache.flume.agent.embedded | 
|---|
| Methods in org.apache.flume.agent.embedded with parameters of type Context | |
|---|---|
|  void | EmbeddedSource.configure(Context context) | 
| Uses of Context in org.apache.flume.channel | 
|---|
| Methods in org.apache.flume.channel with parameters of type Context | |
|---|---|
|  void | SpillableMemoryChannel.configure(Context context)Read parameters from context memoryCapacity = total number of events allowed at one time in the memory queue. | 
|  void | ReplicatingChannelSelector.configure(Context context) | 
|  void | PseudoTxnMemoryChannel.configure(Context context) | 
|  void | MultiplexingChannelSelector.configure(Context context) | 
|  void | MemoryChannel.configure(Context context)Read parameters from context capacity = type long that defines the total number of events allowed at one time in the queue. | 
|  void | ChannelProcessor.configure(Context context)The Context of the associated Source is passed. | 
|  void | AbstractChannel.configure(Context context) | 
| Uses of Context in org.apache.flume.channel.file | 
|---|
| Methods in org.apache.flume.channel.file with parameters of type Context | |
|---|---|
|  void | FileChannel.configure(Context context) | 
| Uses of Context in org.apache.flume.channel.file.encryption | 
|---|
| Methods in org.apache.flume.channel.file.encryption with parameters of type Context | |
|---|---|
|  KeyProvider | KeyProvider.Builder.build(Context context) | 
|  KeyProvider | JCEFileKeyProvider.Builder.build(Context context) | 
| static KeyProvider | KeyProviderFactory.getInstance(String keyProviderType,
            Context context) | 
| Uses of Context in org.apache.flume.channel.jdbc | 
|---|
| Methods in org.apache.flume.channel.jdbc with parameters of type Context | |
|---|---|
|  void | JdbcChannel.configure(Context context) | 
| static JdbcChannelProvider | JdbcChannelProviderFactory.getProvider(Context context,
            String name) | 
|  void | JdbcChannelProvider.initialize(Context context)Initializes the channel provider. | 
| Uses of Context in org.apache.flume.channel.jdbc.impl | 
|---|
| Methods in org.apache.flume.channel.jdbc.impl with parameters of type Context | |
|---|---|
|  void | JdbcChannelProviderImpl.initialize(Context context) | 
| Uses of Context in org.apache.flume.channel.kafka | 
|---|
| Methods in org.apache.flume.channel.kafka with parameters of type Context | |
|---|---|
|  void | KafkaChannel.configure(Context ctx) | 
| Uses of Context in org.apache.flume.client.avro | 
|---|
| Methods in org.apache.flume.client.avro with parameters of type Context | |
|---|---|
|  ReliableSpoolingFileEventReader.Builder | ReliableSpoolingFileEventReader.Builder.deserializerContext(Context deserializerContext) | 
| Uses of Context in org.apache.flume.conf | 
|---|
| Methods in org.apache.flume.conf that return types with arguments of type Context | |
|---|---|
|  Map<String,Context> | FlumeConfiguration.AgentConfiguration.getChannelContext() | 
|  Map<String,Context> | FlumeConfiguration.AgentConfiguration.getSinkContext() | 
|  Map<String,Context> | FlumeConfiguration.AgentConfiguration.getSourceContext() | 
| Methods in org.apache.flume.conf with parameters of type Context | |
|---|---|
|  void | Configurable.configure(Context context)Request the implementing class to (re)configure itself. | 
|  void | ComponentConfiguration.configure(Context context) | 
| static boolean | Configurables.configure(Object target,
          Context context)Check that targetimplementsConfigurableand, if so, ask
 it to configure itself using the suppliedcontext. | 
| static void | Configurables.ensureOptionalNonNull(Context context,
                      String... keys) | 
| static void | Configurables.ensureRequiredNonNull(Context context,
                      String... keys) | 
| Uses of Context in org.apache.flume.conf.channel | 
|---|
| Methods in org.apache.flume.conf.channel with parameters of type Context | |
|---|---|
|  void | ChannelSelectorConfiguration.configure(Context context) | 
|  void | ChannelConfiguration.configure(Context context) | 
| Uses of Context in org.apache.flume.conf.sink | 
|---|
| Methods in org.apache.flume.conf.sink that return Context | |
|---|---|
|  Context | SinkGroupConfiguration.getProcessorContext() | 
| Methods in org.apache.flume.conf.sink with parameters of type Context | |
|---|---|
|  void | SinkProcessorConfiguration.configure(Context context) | 
|  void | SinkGroupConfiguration.configure(Context context) | 
|  void | SinkConfiguration.configure(Context context) | 
|  void | SinkGroupConfiguration.setProcessorContext(Context processorContext) | 
| Uses of Context in org.apache.flume.conf.source | 
|---|
| Methods in org.apache.flume.conf.source with parameters of type Context | |
|---|---|
|  void | SourceConfiguration.configure(Context context) | 
| Uses of Context in org.apache.flume.instrumentation | 
|---|
| Methods in org.apache.flume.instrumentation with parameters of type Context | |
|---|---|
|  void | GangliaServer.configure(Context context) | 
| Uses of Context in org.apache.flume.instrumentation.http | 
|---|
| Methods in org.apache.flume.instrumentation.http with parameters of type Context | |
|---|---|
|  void | HTTPMetricsServer.configure(Context context) | 
| Uses of Context in org.apache.flume.interceptor | 
|---|
| Methods in org.apache.flume.interceptor with parameters of type Context | |
|---|---|
|  void | TimestampInterceptor.Builder.configure(Context context) | 
|  void | StaticInterceptor.Builder.configure(Context context) | 
|  void | SearchAndReplaceInterceptor.Builder.configure(Context context) | 
|  void | RegexFilteringInterceptor.Builder.configure(Context context) | 
|  void | RegexExtractorInterceptorPassThroughSerializer.configure(Context context) | 
|  void | RegexExtractorInterceptorMillisSerializer.configure(Context context) | 
|  void | RegexExtractorInterceptor.Builder.configure(Context context) | 
|  void | HostInterceptor.Builder.configure(Context context) | 
| Uses of Context in org.apache.flume.serialization | 
|---|
| Methods in org.apache.flume.serialization with parameters of type Context | |
|---|---|
|  EventSerializer | HeaderAndBodyTextEventSerializer.Builder.build(Context context,
      OutputStream out) | 
|  EventSerializer | FlumeEventAvroEventSerializer.Builder.build(Context context,
      OutputStream out) | 
|  EventSerializer | EventSerializer.Builder.build(Context context,
      OutputStream out) | 
|  EventSerializer | BodyTextEventSerializer.Builder.build(Context context,
      OutputStream out) | 
|  EventDeserializer | LineDeserializer.Builder.build(Context context,
      ResettableInputStream in) | 
|  EventDeserializer | EventDeserializer.Builder.build(Context context,
      ResettableInputStream in) | 
|  EventDeserializer | AvroEventDeserializer.Builder.build(Context context,
      ResettableInputStream in) | 
|  EventSerDe | EventSerDe.Builder.build(Context context,
      ResettableInputStream in,
      OutputStream out) | 
|  void | AbstractAvroEventSerializer.configure(Context context) | 
| static EventSerializer | EventSerializerFactory.getInstance(String serializerType,
            Context context,
            OutputStream out) | 
| static EventDeserializer | EventDeserializerFactory.getInstance(String deserializerType,
            Context context,
            ResettableInputStream in) | 
| Uses of Context in org.apache.flume.sink | 
|---|
| Methods in org.apache.flume.sink with parameters of type Context | |
|---|---|
|  void | SinkGroup.configure(Context context) | 
|  void | RollingFileSink.configure(Context context) | 
|  void | NullSink.configure(Context context) | 
|  void | LoggerSink.configure(Context context) | 
|  void | LoadBalancingSinkProcessor.configure(Context context) | 
|  void | FailoverSinkProcessor.configure(Context context) | 
|  void | DefaultSinkProcessor.configure(Context context) | 
|  void | AbstractSinkSelector.configure(Context context) | 
|  void | AbstractRpcSink.configure(Context context) | 
| static SinkProcessor | SinkProcessorFactory.getProcessor(Context context,
             List<Sink> sinks)Creates a sink processor and configures it using the provided context | 
| Uses of Context in org.apache.flume.sink.elasticsearch | 
|---|
| Methods in org.apache.flume.sink.elasticsearch with parameters of type Context | |
|---|---|
|  void | TimeBasedIndexNameBuilder.configure(Context context) | 
|  void | SimpleIndexNameBuilder.configure(Context context) | 
|  void | EventSerializerIndexRequestBuilderFactory.configure(Context context) | 
|  void | ElasticSearchSink.configure(Context context) | 
|  void | ElasticSearchLogStashEventSerializer.configure(Context context) | 
|  void | ElasticSearchDynamicSerializer.configure(Context context) | 
| abstract  void | AbstractElasticSearchIndexRequestBuilderFactory.configure(Context arg0) | 
| Uses of Context in org.apache.flume.sink.elasticsearch.client | 
|---|
| Methods in org.apache.flume.sink.elasticsearch.client with parameters of type Context | |
|---|---|
|  void | ElasticSearchTransportClient.configure(Context context) | 
|  void | ElasticSearchRestClient.configure(Context context) | 
| Uses of Context in org.apache.flume.sink.hbase | 
|---|
| Methods in org.apache.flume.sink.hbase with parameters of type Context | |
|---|---|
|  void | SimpleHbaseEventSerializer.configure(Context context) | 
|  void | SimpleAsyncHbaseEventSerializer.configure(Context context) | 
|  void | RegexHbaseEventSerializer.configure(Context context) | 
|  void | HBaseSink.configure(Context context) | 
|  void | AsyncHBaseSink.configure(Context context) | 
| Uses of Context in org.apache.flume.sink.hdfs | 
|---|
| Methods in org.apache.flume.sink.hdfs with parameters of type Context | |
|---|---|
|  SequenceFileSerializer | SequenceFileSerializer.Builder.build(Context context) | 
|  SequenceFileSerializer | HDFSWritableSerializer.Builder.build(Context context) | 
|  SequenceFileSerializer | HDFSTextSerializer.Builder.build(Context context) | 
|  EventSerializer | AvroEventSerializer.Builder.build(Context context,
      OutputStream out) | 
|  void | HDFSSequenceFile.configure(Context context) | 
|  void | HDFSEventSink.configure(Context context) | 
|  void | HDFSDataStream.configure(Context context) | 
|  void | HDFSCompressedDataStream.configure(Context context) | 
|  void | AvroEventSerializer.configure(Context context) | 
|  void | AbstractHDFSWriter.configure(Context context) | 
| Uses of Context in org.apache.flume.sink.hive | 
|---|
| Methods in org.apache.flume.sink.hive with parameters of type Context | |
|---|---|
|  void | HiveSink.configure(Context context) | 
|  void | HiveJsonSerializer.configure(Context context) | 
|  void | HiveDelimitedTextSerializer.configure(Context context) | 
| Uses of Context in org.apache.flume.sink.irc | 
|---|
| Methods in org.apache.flume.sink.irc with parameters of type Context | |
|---|---|
|  void | IRCSink.configure(Context context) | 
| Uses of Context in org.apache.flume.sink.kafka | 
|---|
| Methods in org.apache.flume.sink.kafka with parameters of type Context | |
|---|---|
|  void | KafkaSink.configure(Context context)We configure the sink and generate properties for the Kafka Producer Kafka producer properties is generated as follows: 1. | 
| static Properties | KafkaSinkUtil.getKafkaProperties(Context context) | 
| Uses of Context in org.apache.flume.sink.kite | 
|---|
| Methods in org.apache.flume.sink.kite with parameters of type Context | |
|---|---|
|  void | DatasetSink.configure(Context context) | 
| Uses of Context in org.apache.flume.sink.kite.parser | 
|---|
| Methods in org.apache.flume.sink.kite.parser with parameters of type Context | |
|---|---|
|  EntityParser<E> | EntityParser.Builder.build(org.apache.avro.Schema datasetSchema,
      Context config) | 
|  EntityParser<org.apache.avro.generic.GenericRecord> | AvroParser.Builder.build(org.apache.avro.Schema datasetSchema,
      Context config) | 
|  EntityParser<org.apache.avro.generic.GenericRecord> | EntityParserFactory.newParser(org.apache.avro.Schema datasetSchema,
          Context config) | 
| Uses of Context in org.apache.flume.sink.kite.policy | 
|---|
| Methods in org.apache.flume.sink.kite.policy with parameters of type Context | |
|---|---|
|  FailurePolicy | SavePolicy.Builder.build(Context config) | 
|  FailurePolicy | RetryPolicy.Builder.build(Context config) | 
|  FailurePolicy | FailurePolicy.Builder.build(Context config)Build a new FailurePolicy | 
|  FailurePolicy | FailurePolicyFactory.newPolicy(Context config) | 
| Uses of Context in org.apache.flume.sink.solr.morphline | 
|---|
| Methods in org.apache.flume.sink.solr.morphline with parameters of type Context | |
|---|---|
|  BlobDeserializer | BlobDeserializer.Builder.build(Context context,
      ResettableInputStream in) | 
|  void | UUIDInterceptor.Builder.configure(Context context) | 
|  void | MorphlineSolrSink.configure(Context context) | 
|  void | MorphlineSink.configure(Context context) | 
|  void | MorphlineInterceptor.Builder.configure(Context context) | 
|  void | MorphlineHandlerImpl.configure(Context context) | 
|  void | BlobHandler.configure(Context context) | 
| Constructors in org.apache.flume.sink.solr.morphline with parameters of type Context | |
|---|---|
| BlobDeserializer(Context context,
                 ResettableInputStream in) | |
| MorphlineInterceptor(Context context) | |
| UUIDInterceptor(Context context) | |
| Uses of Context in org.apache.flume.source | 
|---|
| Methods in org.apache.flume.source with parameters of type Context | |
|---|---|
|  void | ThriftSource.configure(Context context) | 
|  void | SyslogUDPSource.configure(Context context) | 
|  void | SyslogTcpSource.configure(Context context) | 
|  void | StressSource.configure(Context context)Read parameters from context -maxTotalEvents = type long that defines the total number of Events to be sent -maxSuccessfulEvents = type long that defines the number of successful Events -size = type int that defines the number of bytes in each Event -batchSize = type int that defines the number of Events being sent in one batch | 
|  void | SpoolDirectorySource.configure(Context context) | 
|  void | SequenceGeneratorSource.configure(Context context)Read parameters from context batchSize = type int that defines the size of event batches | 
|  void | NetcatSource.configure(Context context) | 
|  void | MultiportSyslogTCPSource.configure(Context context) | 
|  void | ExecSource.configure(Context context) | 
|  void | BasicSourceSemantics.configure(Context context) | 
|  void | AvroSource.configure(Context context) | 
| protected abstract  void | BasicSourceSemantics.doConfigure(Context context) | 
| Uses of Context in org.apache.flume.source.avroLegacy | 
|---|
| Methods in org.apache.flume.source.avroLegacy with parameters of type Context | |
|---|---|
|  void | AvroLegacySource.configure(Context context) | 
| Uses of Context in org.apache.flume.source.http | 
|---|
| Methods in org.apache.flume.source.http with parameters of type Context | |
|---|---|
|  void | JSONHandler.configure(Context context) | 
|  void | HTTPSource.configure(Context context) | 
| Uses of Context in org.apache.flume.source.jms | 
|---|
| Methods in org.apache.flume.source.jms with parameters of type Context | |
|---|---|
|  JMSMessageConverter | JMSMessageConverter.Builder.build(Context context) | 
|  JMSMessageConverter | DefaultJMSMessageConverter.Builder.build(Context context) | 
| protected  void | JMSSource.doConfigure(Context context) | 
| Uses of Context in org.apache.flume.source.kafka | 
|---|
| Methods in org.apache.flume.source.kafka with parameters of type Context | |
|---|---|
|  void | KafkaSource.configure(Context context)We configure the source and generate properties for the Kafka Consumer Kafka Consumer properties are generated as follows: 1. | 
| static Properties | KafkaSourceUtil.getKafkaProperties(Context context) | 
| Uses of Context in org.apache.flume.source.scribe | 
|---|
| Methods in org.apache.flume.source.scribe with parameters of type Context | |
|---|---|
|  void | ScribeSource.configure(Context context) | 
| Uses of Context in org.apache.flume.source.thriftLegacy | 
|---|
| Methods in org.apache.flume.source.thriftLegacy with parameters of type Context | |
|---|---|
|  void | ThriftLegacySource.configure(Context context) | 
| Uses of Context in org.apache.flume.source.twitter | 
|---|
| Methods in org.apache.flume.source.twitter with parameters of type Context | |
|---|---|
|  void | TwitterSource.configure(Context context) | 
| 
 | ||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||