A B C D E F G H I J K L M N O P Q R S T U V W X Z 

A

AbstractAvroEventSerializer<T> - Class in org.apache.flume.serialization
This is a helper class provided to make it straightforward to serialize Flume events into Avro data.
AbstractAvroEventSerializer() - Constructor for class org.apache.flume.serialization.AbstractAvroEventSerializer
 
AbstractChannel - Class in org.apache.flume.channel
 
AbstractChannel() - Constructor for class org.apache.flume.channel.AbstractChannel
 
AbstractChannelSelector - Class in org.apache.flume.channel
 
AbstractChannelSelector() - Constructor for class org.apache.flume.channel.AbstractChannelSelector
 
AbstractConfigurationProvider - Class in org.apache.flume.node
 
AbstractConfigurationProvider(String) - Constructor for class org.apache.flume.node.AbstractConfigurationProvider
 
AbstractElasticSearchIndexRequestBuilderFactory - Class in org.apache.flume.sink.elasticsearch
Abstract base class for custom implementations of ElasticSearchIndexRequestBuilderFactory.
AbstractElasticSearchIndexRequestBuilderFactory(FastDateFormat) - Constructor for class org.apache.flume.sink.elasticsearch.AbstractElasticSearchIndexRequestBuilderFactory
Constructor for subclasses
AbstractEventDrivenSource - Class in org.apache.flume.source
Base class which ensures sub-classes will inherit all the properties of BasicSourceSemantics.
AbstractEventDrivenSource() - Constructor for class org.apache.flume.source.AbstractEventDrivenSource
 
AbstractHDFSWriter - Class in org.apache.flume.sink.hdfs
 
AbstractHDFSWriter() - Constructor for class org.apache.flume.sink.hdfs.AbstractHDFSWriter
 
AbstractPollableSource - Class in org.apache.flume.source
Base class which ensures sub-classes will inherit all the properties of BasicSourceSemantics in addition to: Ensuring when configure/start throw an exception process will not be called Ensure that process will not be called unless configure and start have successfully been called
AbstractPollableSource() - Constructor for class org.apache.flume.source.AbstractPollableSource
 
AbstractRpcClient - Class in org.apache.flume.api
 
AbstractRpcClient() - Constructor for class org.apache.flume.api.AbstractRpcClient
 
AbstractRpcSink - Class in org.apache.flume.sink
This sink provides the basic RPC functionality for Flume.
AbstractRpcSink() - Constructor for class org.apache.flume.sink.AbstractRpcSink
 
AbstractSink - Class in org.apache.flume.sink
 
AbstractSink() - Constructor for class org.apache.flume.sink.AbstractSink
 
AbstractSinkProcessor - Class in org.apache.flume.sink
A convenience base class for sink processors.
AbstractSinkProcessor() - Constructor for class org.apache.flume.sink.AbstractSinkProcessor
 
AbstractSinkSelector - Class in org.apache.flume.sink
 
AbstractSinkSelector() - Constructor for class org.apache.flume.sink.AbstractSinkSelector
 
AbstractSource - Class in org.apache.flume.source
 
AbstractSource() - Constructor for class org.apache.flume.source.AbstractSource
 
activateOptions() - Method in class org.apache.flume.clients.log4jappender.LoadBalancingLog4jAppender
Activate the options set using setHosts(), setSelector and setMaxBackoff
activateOptions() - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
Activate the options set using setPort() and setHostname()
ACTIVE_KEY - Static variable in class org.apache.flume.channel.file.encryption.EncryptionConfiguration
Encryption key alias, default is null.
ACTIVELOGS_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
add(CounterGroup) - Method in class org.apache.flume.CounterGroup
 
addActiveLogs(ProtosFactory.ActiveLog) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
repeated .ActiveLog activeLogs = 5;
addActiveLogs(int, ProtosFactory.ActiveLog) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
repeated .ActiveLog activeLogs = 5;
addActiveLogs(ProtosFactory.ActiveLog.Builder) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
repeated .ActiveLog activeLogs = 5;
addActiveLogs(int, ProtosFactory.ActiveLog.Builder) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
repeated .ActiveLog activeLogs = 5;
addActiveLogsBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
repeated .ActiveLog activeLogs = 5;
addActiveLogsBuilder(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
repeated .ActiveLog activeLogs = 5;
addAllActiveLogs(Iterable<? extends ProtosFactory.ActiveLog>) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
repeated .ActiveLog activeLogs = 5;
addAllHeaders(Iterable<? extends ProtosFactory.FlumeEventHeader>) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
repeated .FlumeEventHeader headers = 1;
addAndGet(String, Long) - Method in class org.apache.flume.CounterGroup
 
addAndGet(String, long) - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
Atomically adds the delta to the current value for this key
addChannel(String, Channel) - Method in interface org.apache.flume.node.MaterializedConfiguration
 
addChannel(String, Channel) - Method in class org.apache.flume.node.SimpleMaterializedConfiguration
 
addComplexField(XContentBuilder, String, XContentType, byte[]) - Static method in class org.apache.flume.sink.elasticsearch.ContentBuilderUtil
 
addEvent(Event, IndexNameBuilder, String, long) - Method in interface org.apache.flume.sink.elasticsearch.client.ElasticSearchClient
Add new event to the bulk
addEvent(Event, IndexNameBuilder, String, long) - Method in class org.apache.flume.sink.elasticsearch.client.ElasticSearchRestClient
 
addEvent(Event, IndexNameBuilder, String, long) - Method in class org.apache.flume.sink.elasticsearch.client.ElasticSearchTransportClient
 
addFormats(Map<String, String>) - Method in class org.apache.flume.source.SyslogUtils
 
addHeaders(ProtosFactory.FlumeEventHeader) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
repeated .FlumeEventHeader headers = 1;
addHeaders(int, ProtosFactory.FlumeEventHeader) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
repeated .FlumeEventHeader headers = 1;
addHeaders(ProtosFactory.FlumeEventHeader.Builder) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
repeated .FlumeEventHeader headers = 1;
addHeaders(int, ProtosFactory.FlumeEventHeader.Builder) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
repeated .FlumeEventHeader headers = 1;
addHeadersBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
repeated .FlumeEventHeader headers = 1;
addHeadersBuilder(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
repeated .FlumeEventHeader headers = 1;
addSimpleField(XContentBuilder, String, byte[]) - Static method in class org.apache.flume.sink.elasticsearch.ContentBuilderUtil
 
addSinkRunner(String, SinkRunner) - Method in interface org.apache.flume.node.MaterializedConfiguration
 
addSinkRunner(String, SinkRunner) - Method in class org.apache.flume.node.SimpleMaterializedConfiguration
 
addSourceRunner(String, SourceRunner) - Method in interface org.apache.flume.node.MaterializedConfiguration
 
addSourceRunner(String, SourceRunner) - Method in class org.apache.flume.node.SimpleMaterializedConfiguration
 
addToEventAcceptedCount(long) - Method in class org.apache.flume.instrumentation.SourceCounter
 
addToEventDrainAttemptCount(long) - Method in class org.apache.flume.instrumentation.SinkCounter
 
addToEventDrainSuccessCount(long) - Method in class org.apache.flume.instrumentation.SinkCounter
 
addToEventPutSuccessCount(long) - Method in class org.apache.flume.instrumentation.ChannelCounter
 
addToEventReceivedCount(long) - Method in class org.apache.flume.instrumentation.SourceCounter
 
addToEvents(ThriftFlumeEvent) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
addToEventTakeSuccessCount(long) - Method in class org.apache.flume.instrumentation.ChannelCounter
 
addToMessages(LogEntry) - Method in class org.apache.flume.source.scribe.Scribe.Log_args
 
AESCTRNoPaddingProvider - Class in org.apache.flume.channel.file.encryption
 
AESCTRNoPaddingProvider() - Constructor for class org.apache.flume.channel.file.encryption.AESCTRNoPaddingProvider
 
AESCTRNoPaddingProvider.DecryptorBuilder - Class in org.apache.flume.channel.file.encryption
 
AESCTRNoPaddingProvider.DecryptorBuilder() - Constructor for class org.apache.flume.channel.file.encryption.AESCTRNoPaddingProvider.DecryptorBuilder
 
AESCTRNoPaddingProvider.EncryptorBuilder - Class in org.apache.flume.channel.file.encryption
 
AESCTRNoPaddingProvider.EncryptorBuilder() - Constructor for class org.apache.flume.channel.file.encryption.AESCTRNoPaddingProvider.EncryptorBuilder
 
afterCreate() - Method in class org.apache.flume.serialization.AbstractAvroEventSerializer
 
afterCreate() - Method in class org.apache.flume.serialization.BodyTextEventSerializer
 
afterCreate() - Method in interface org.apache.flume.serialization.EventSerializer
Hook to write a header after file is opened for the first time.
afterCreate() - Method in class org.apache.flume.serialization.HeaderAndBodyTextEventSerializer
 
afterCreate() - Method in class org.apache.flume.sink.hdfs.AvroEventSerializer
 
afterReopen() - Method in class org.apache.flume.serialization.AbstractAvroEventSerializer
 
afterReopen() - Method in class org.apache.flume.serialization.BodyTextEventSerializer
 
afterReopen() - Method in interface org.apache.flume.serialization.EventSerializer
Hook to handle any framing needed when file is re-opened (for write).
Could have been named afterOpenForAppend().
afterReopen() - Method in class org.apache.flume.serialization.HeaderAndBodyTextEventSerializer
 
afterReopen() - Method in class org.apache.flume.sink.hdfs.AvroEventSerializer
 
allocate(int) - Static method in class org.apache.flume.tools.DirectMemoryUtils
 
annotateBaseName(Boolean) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
 
annotateFileName(Boolean) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
 
append(ThriftFlumeEvent, AsyncMethodCallback<ThriftFlumeEventServer.AsyncClient.append_call>) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient
 
append(ThriftFlumeEvent, AsyncMethodCallback<ThriftFlumeEventServer.AsyncClient.append_call>) - Method in interface com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncIface
 
append(ThriftFlumeEvent) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
 
append(ThriftFlumeEvent) - Method in interface com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Iface
 
append(Event) - Method in class org.apache.flume.api.AbstractRpcClient
 
append(Event) - Method in class org.apache.flume.api.FailoverRpcClient
Tries to append an event to the currently connected client.
append(Event) - Method in class org.apache.flume.api.LoadBalancingRpcClient
 
append(Event) - Method in class org.apache.flume.api.NettyAvroRpcClient
 
append(Event) - Method in interface org.apache.flume.api.RpcClient
Send a single Event to the associated Flume source.
append(Event) - Method in class org.apache.flume.api.ThriftRpcClient
 
append(LoggingEvent) - Method in class org.apache.flume.clients.log4jappender.LoadBalancingLog4jAppender
 
append(LoggingEvent) - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
Append the LoggingEvent, to send to the first Flume hop.
append(Event) - Method in class org.apache.flume.sink.hdfs.HDFSCompressedDataStream
 
append(Event) - Method in class org.apache.flume.sink.hdfs.HDFSDataStream
 
append(Event) - Method in class org.apache.flume.sink.hdfs.HDFSSequenceFile
 
append(Event) - Method in interface org.apache.flume.sink.hdfs.HDFSWriter
 
append(AvroFlumeOGEvent) - Method in class org.apache.flume.source.avroLegacy.AvroLegacySource
 
append(AvroFlumeEvent) - Method in class org.apache.flume.source.AvroSource
 
append(ThriftFlumeEvent, AsyncMethodCallback<ThriftSourceProtocol.AsyncClient.append_call>) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.AsyncClient
 
append(ThriftFlumeEvent, AsyncMethodCallback<ThriftSourceProtocol.AsyncClient.append_call>) - Method in interface org.apache.flume.thrift.ThriftSourceProtocol.AsyncIface
 
append(ThriftFlumeEvent) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.Client
 
append(ThriftFlumeEvent) - Method in interface org.apache.flume.thrift.ThriftSourceProtocol.Iface
 
appendBatch(List<Event>) - Method in class org.apache.flume.api.AbstractRpcClient
 
appendBatch(List<Event>) - Method in class org.apache.flume.api.FailoverRpcClient
Tries to append a list of events to the currently connected client.
appendBatch(List<Event>) - Method in class org.apache.flume.api.LoadBalancingRpcClient
 
appendBatch(List<Event>) - Method in class org.apache.flume.api.NettyAvroRpcClient
 
appendBatch(List<Event>) - Method in interface org.apache.flume.api.RpcClient
Send a list of events to the associated Flume source.
appendBatch(List<Event>) - Method in class org.apache.flume.api.ThriftRpcClient
 
appendBatch(List<AvroFlumeEvent>) - Method in class org.apache.flume.source.AvroSource
 
appendBatch(List<ThriftFlumeEvent>, AsyncMethodCallback<ThriftSourceProtocol.AsyncClient.appendBatch_call>) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.AsyncClient
 
appendBatch(List<ThriftFlumeEvent>, AsyncMethodCallback<ThriftSourceProtocol.AsyncClient.appendBatch_call>) - Method in interface org.apache.flume.thrift.ThriftSourceProtocol.AsyncIface
 
appendBatch(List<ThriftFlumeEvent>) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.Client
 
appendBatch(List<ThriftFlumeEvent>) - Method in interface org.apache.flume.thrift.ThriftSourceProtocol.Iface
 
appendField(XContentBuilder, String, byte[]) - Static method in class org.apache.flume.sink.elasticsearch.ContentBuilderUtil
 
Application - Class in org.apache.flume.node
 
Application() - Constructor for class org.apache.flume.node.Application
 
Application(List<LifecycleAware>) - Constructor for class org.apache.flume.node.Application
 
AsyncHbaseEventSerializer - Interface in org.apache.flume.sink.hbase
Interface for an event serializer which serializes the headers and body of an event to write them to hbase.
AsyncHBaseSink - Class in org.apache.flume.sink.hbase
A simple sink which reads events from a channel and writes them to HBase.
AsyncHBaseSink() - Constructor for class org.apache.flume.sink.hbase.AsyncHBaseSink
 
AsyncHBaseSink(Configuration) - Constructor for class org.apache.flume.sink.hbase.AsyncHBaseSink
 
AVG_EVENT_SIZE - Static variable in class org.apache.flume.channel.SpillableMemoryChannel
Estimated average size of events expected to be in the channel
AVRO_SCHEMA_HEADER_HASH - Static variable in class org.apache.flume.serialization.AvroEventDeserializer
 
AVRO_SCHEMA_HEADER_LITERAL - Static variable in class org.apache.flume.serialization.AvroEventDeserializer
 
AVRO_SCHEMA_LITERAL_HEADER - Static variable in class org.apache.flume.sink.hdfs.AvroEventSerializer
 
AVRO_SCHEMA_URL_HEADER - Static variable in class org.apache.flume.sink.hdfs.AvroEventSerializer
 
AvroCLIClient - Class in org.apache.flume.client.avro
 
AvroCLIClient() - Constructor for class org.apache.flume.client.avro.AvroCLIClient
 
avroClient - Variable in class org.apache.flume.source.avroLegacy.AvroLegacySource
 
AvroEventDeserializer - Class in org.apache.flume.serialization
A deserializer that parses Avro container files, generating one Flume event per record in the Avro file, and storing binary avro-encoded records in the Flume event body.
AvroEventDeserializer.AvroSchemaType - Enum in org.apache.flume.serialization
 
AvroEventDeserializer.Builder - Class in org.apache.flume.serialization
 
AvroEventDeserializer.Builder() - Constructor for class org.apache.flume.serialization.AvroEventDeserializer.Builder
 
AvroEventSerializer - Class in org.apache.flume.sink.hdfs
This class serializes Flume events into Avro data files.
AvroEventSerializer.Builder - Class in org.apache.flume.sink.hdfs
 
AvroEventSerializer.Builder() - Constructor for class org.apache.flume.sink.hdfs.AvroEventSerializer.Builder
 
AvroEventSerializerConfigurationConstants - Class in org.apache.flume.serialization
 
AvroEventSerializerConfigurationConstants() - Constructor for class org.apache.flume.serialization.AvroEventSerializerConfigurationConstants
 
AvroLegacySource - Class in org.apache.flume.source.avroLegacy
A Source implementation that receives Avro events from Avro sink of Flume OG
AvroLegacySource() - Constructor for class org.apache.flume.source.avroLegacy.AvroLegacySource
 
AvroSink - Class in org.apache.flume.sink
A Sink implementation that can send events to an RPC server (such as Flume's AvroSource).
AvroSink() - Constructor for class org.apache.flume.sink.AvroSink
 
AvroSource - Class in org.apache.flume.source
A Source implementation that receives Avro events from clients that implement AvroSourceProtocol.
AvroSource() - Constructor for class org.apache.flume.source.AvroSource
 

B

BACKUP_CHECKPOINT_DIR - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
The directory to which the checkpoint must be backed up
BACKUPCHECKPOINTPOSITION_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
BACKUPCHECKPOINTWRITEORDERID_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
BadCheckpointException - Exception in org.apache.flume.channel.file
Exception thrown when the checkpoint directory contains invalid data, probably due to the channel stopping while the checkpoint was written.
BadCheckpointException(String) - Constructor for exception org.apache.flume.channel.file.BadCheckpointException
 
BadCheckpointException(String, Throwable) - Constructor for exception org.apache.flume.channel.file.BadCheckpointException
 
BASENAME_HEADER - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
Whether to include the basename of a file in a header.
BASENAME_HEADER_KEY - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
Header in which to put the basename of file.
baseNameHeader(String) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
 
BasicChannelSemantics - Class in org.apache.flume.channel
An implementation of basic Channel semantics, including the implied thread-local semantics of the Transaction class, which is required to extend BasicTransactionSemantics.
BasicChannelSemantics() - Constructor for class org.apache.flume.channel.BasicChannelSemantics
 
BasicConfigurationConstants - Class in org.apache.flume.conf
 
BasicSourceSemantics - Class in org.apache.flume.source
Alternative to AbstractSource, which: Ensure configure cannot be called while started Exceptions thrown during configure, start, stop put source in ERROR state Exceptions thrown during start, stop will be logged but not re-thrown. Exception in configure disables starting
BasicSourceSemantics() - Constructor for class org.apache.flume.source.BasicSourceSemantics
 
BasicTransactionSemantics - Class in org.apache.flume.channel
An implementation of basic Transaction semantics designed to work in concert with BasicChannelSemantics to simplify creation of robust Channel implementations.
BasicTransactionSemantics() - Constructor for class org.apache.flume.channel.BasicTransactionSemantics
 
BasicTransactionSemantics.State - Enum in org.apache.flume.channel
The state of the Transaction to which it belongs.
BATCH_DURATION_MILLIS - Static variable in class org.apache.flume.sink.solr.morphline.MorphlineSink
 
BATCH_SIZE - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
Maximum number of events the sink should take from the channel per transaction, if available.
BATCH_SIZE - Static variable in class org.apache.flume.sink.solr.morphline.MorphlineSink
 
BATCH_SIZE - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
BATCH_SIZE - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
What size to batch with before sending to ChannelProcessor.
BATCH_SIZE_DEFAULT - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
BatchAware - Interface in org.apache.flume.sink.hbase
This interface allows for implementing HBase serializers that are aware of batching.
batchSize - Variable in class org.apache.flume.api.AbstractRpcClient
 
beforeClose() - Method in class org.apache.flume.serialization.AbstractAvroEventSerializer
 
beforeClose() - Method in class org.apache.flume.serialization.BodyTextEventSerializer
 
beforeClose() - Method in interface org.apache.flume.serialization.EventSerializer
Hook to write a trailer before the stream is closed.
beforeClose() - Method in class org.apache.flume.serialization.HeaderAndBodyTextEventSerializer
 
beforeClose() - Method in class org.apache.flume.sink.hdfs.AvroEventSerializer
 
begin() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
begin() - Method in class org.apache.flume.channel.jdbc.impl.JdbcTransactionImpl
 
begin() - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel.NoOpTransaction
 
begin() - Method in interface org.apache.flume.Transaction
Starts a transaction boundary for the current channel operation.
beginTransaction() - Method in interface org.apache.flume.sink.solr.morphline.MorphlineHandler
Begins a transaction
beginTransaction() - Method in class org.apache.flume.sink.solr.morphline.MorphlineHandlerImpl
 
BlobDeserializer - Class in org.apache.flume.sink.solr.morphline
A deserializer that reads a Binary Large Object (BLOB) per event, typically one BLOB per file; To be used in conjunction with Flume SpoolDirectorySource.
BlobDeserializer(Context, ResettableInputStream) - Constructor for class org.apache.flume.sink.solr.morphline.BlobDeserializer
 
BlobDeserializer.Builder - Class in org.apache.flume.sink.solr.morphline
Builder implementations MUST have a public no-arg constructor
BlobDeserializer.Builder() - Constructor for class org.apache.flume.sink.solr.morphline.BlobDeserializer.Builder
 
BlobHandler - Class in org.apache.flume.sink.solr.morphline
BlobHandler for HTTPSource that returns event that contains the request parameters as well as the Binary Large Object (BLOB) uploaded with this request.
BlobHandler() - Constructor for class org.apache.flume.sink.solr.morphline.BlobHandler
 
body - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
body - Variable in class org.apache.flume.thrift.ThriftFlumeEvent
 
BODY_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
BodyTextEventSerializer - Class in org.apache.flume.serialization
This class simply writes the body of the event to the output stream and appends a newline after each event.
BodyTextEventSerializer.Builder - Class in org.apache.flume.serialization
 
BodyTextEventSerializer.Builder() - Constructor for class org.apache.flume.serialization.BodyTextEventSerializer.Builder
 
BucketClosedException - Exception in org.apache.flume.sink.hdfs
 
BucketClosedException(String) - Constructor for exception org.apache.flume.sink.hdfs.BucketClosedException
 
BucketPath - Class in org.apache.flume.formatter.output
 
BucketPath() - Constructor for class org.apache.flume.formatter.output.BucketPath
 
buffer - Variable in class org.apache.flume.instrumentation.GangliaServer
 
BUFFER_MAX_LINE_LENGTH - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
Deprecated.
BUFFER_MAX_LINES - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
Deprecated.
BUFFER_SIZE - Static variable in class org.apache.flume.instrumentation.GangliaServer
 
bufferForBody() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
bufferForBody() - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
build() - Method in class org.apache.flume.channel.file.encryption.AESCTRNoPaddingProvider.DecryptorBuilder
 
build() - Method in class org.apache.flume.channel.file.encryption.AESCTRNoPaddingProvider.EncryptorBuilder
 
build() - Method in class org.apache.flume.channel.file.encryption.CipherProvider.Decryptor.Builder
 
build() - Method in class org.apache.flume.channel.file.encryption.CipherProvider.Encryptor.Builder
 
build(Context) - Method in class org.apache.flume.channel.file.encryption.JCEFileKeyProvider.Builder
 
build(Context) - Method in interface org.apache.flume.channel.file.encryption.KeyProvider.Builder
 
build() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
 
build() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
 
build() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
 
build() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
 
build() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
 
build() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
 
build() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
 
build() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
 
build() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback.Builder
 
build() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
 
build() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter.Builder
 
build() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
 
build() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
 
build() - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
 
build() - Method in class org.apache.flume.interceptor.HostInterceptor.Builder
 
build() - Method in interface org.apache.flume.interceptor.Interceptor.Builder
 
build() - Method in class org.apache.flume.interceptor.RegexExtractorInterceptor.Builder
 
build() - Method in class org.apache.flume.interceptor.RegexFilteringInterceptor.Builder
 
build() - Method in class org.apache.flume.interceptor.StaticInterceptor.Builder
 
build() - Method in class org.apache.flume.interceptor.TimestampInterceptor.Builder
 
build(Context, ResettableInputStream) - Method in class org.apache.flume.serialization.AvroEventDeserializer.Builder
 
build(Context, OutputStream) - Method in class org.apache.flume.serialization.BodyTextEventSerializer.Builder
 
build(Context, ResettableInputStream) - Method in interface org.apache.flume.serialization.EventDeserializer.Builder
 
build(Context, ResettableInputStream, OutputStream) - Method in interface org.apache.flume.serialization.EventSerDe.Builder
 
build(Context, OutputStream) - Method in interface org.apache.flume.serialization.EventSerializer.Builder
 
build(Context, OutputStream) - Method in class org.apache.flume.serialization.FlumeEventAvroEventSerializer.Builder
 
build(Context, OutputStream) - Method in class org.apache.flume.serialization.HeaderAndBodyTextEventSerializer.Builder
 
build(Context, ResettableInputStream) - Method in class org.apache.flume.serialization.LineDeserializer.Builder
 
build(Context, OutputStream) - Method in class org.apache.flume.sink.hdfs.AvroEventSerializer.Builder
 
build(Context) - Method in class org.apache.flume.sink.hdfs.HDFSTextSerializer.Builder
 
build(Context) - Method in class org.apache.flume.sink.hdfs.HDFSWritableSerializer.Builder
 
build(Context) - Method in interface org.apache.flume.sink.hdfs.SequenceFileSerializer.Builder
 
build(Context, ResettableInputStream) - Method in class org.apache.flume.sink.solr.morphline.BlobDeserializer.Builder
 
build() - Method in class org.apache.flume.sink.solr.morphline.MorphlineInterceptor.Builder
 
build() - Method in class org.apache.flume.sink.solr.morphline.UUIDInterceptor.Builder
 
build(Context) - Method in class org.apache.flume.source.jms.DefaultJMSMessageConverter.Builder
 
build(Context) - Method in interface org.apache.flume.source.jms.JMSMessageConverter.Builder
 
buildPartial() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
 
buildPartial() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
 
buildPartial() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
 
buildPartial() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
 
buildPartial() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
 
buildPartial() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
 
buildPartial() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
 
buildPartial() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
 
buildPartial() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback.Builder
 
buildPartial() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
 
buildPartial() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter.Builder
 
buildPartial() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
 
BYTE_CAPACITY - Static variable in class org.apache.flume.channel.SpillableMemoryChannel
max number of bytes used for all events in the queue.
BYTE_CAPACITY_BUFFER_PERCENTAGE - Static variable in class org.apache.flume.channel.SpillableMemoryChannel
percent of buffer between byteCapacity and the estimated event size.

C

CAPACITY - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
Maximum capacity of the channel.
CAPACITY - Static variable in class org.apache.flume.channel.SpillableMemoryChannel
file channel capacity overridden by Spillable Channel
category - Variable in class org.apache.flume.source.scribe.LogEntry
 
cf - Variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
 
CHANNEL - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
Prefix for channel properties
Channel - Interface in org.apache.flume
A channel connects a Source to a Sink.
channel - Variable in class org.apache.flume.conf.sink.SinkConfiguration
 
CHANNEL_NAME_MAX_LENGTH - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
The maximum length of channel name.
CHANNEL_PREFIX - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
Prefix for passing configuration parameters to the channel
CHANNEL_TYPE - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
Channel type, choices are `memory' or `file'
CHANNEL_TYPE_FILE - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
File based channel which stores events in on local disk.
CHANNEL_TYPE_MEMORY - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
Memory channel which stores events in heap.
CHANNEL_TYPE_SPILLABLEMEMORY - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
Spillable Memory channel which stores events in heap.
ChannelConfiguration - Class in org.apache.flume.conf.channel
 
ChannelConfiguration(String) - Constructor for class org.apache.flume.conf.channel.ChannelConfiguration
 
ChannelConfiguration.ChannelConfigurationType - Enum in org.apache.flume.conf.channel
 
channelCounter - Variable in class org.apache.flume.channel.SpillableMemoryChannel
 
ChannelCounter - Class in org.apache.flume.instrumentation
 
ChannelCounter(String) - Constructor for class org.apache.flume.instrumentation.ChannelCounter
 
ChannelCounterMBean - Interface in org.apache.flume.instrumentation
This interface represents a channel counter mbean.
ChannelException - Exception in org.apache.flume
A channel exception is raised whenever a channel operation fails.
ChannelException(String) - Constructor for exception org.apache.flume.ChannelException
 
ChannelException(Throwable) - Constructor for exception org.apache.flume.ChannelException
 
ChannelException(String, Throwable) - Constructor for exception org.apache.flume.ChannelException
 
ChannelFactory - Interface in org.apache.flume
 
ChannelFullException - Exception in org.apache.flume
 
ChannelFullException(String) - Constructor for exception org.apache.flume.ChannelFullException
 
ChannelFullException(Throwable) - Constructor for exception org.apache.flume.ChannelFullException
 
ChannelFullException(String, Throwable) - Constructor for exception org.apache.flume.ChannelFullException
 
channelNames - Variable in class org.apache.flume.conf.channel.ChannelSelectorConfiguration
 
ChannelProcessor - Class in org.apache.flume.channel
A channel processor exposes operations to put Events into Channels.
ChannelProcessor(ChannelSelector) - Constructor for class org.apache.flume.channel.ChannelProcessor
 
ChannelProcessorCounter - Class in org.apache.flume.instrumentation
 
ChannelProcessorCounter(String) - Constructor for class org.apache.flume.instrumentation.ChannelProcessorCounter
 
channels - Variable in class org.apache.flume.conf.source.SourceConfiguration
 
ChannelSelector - Interface in org.apache.flume
Allows the selection of a subset of channels from the given set based on its implementation policy.
ChannelSelectorConfiguration - Class in org.apache.flume.conf.channel
 
ChannelSelectorConfiguration(String) - Constructor for class org.apache.flume.conf.channel.ChannelSelectorConfiguration
 
ChannelSelectorConfiguration.ChannelSelectorConfigurationType - Enum in org.apache.flume.conf.channel
 
ChannelSelectorFactory - Class in org.apache.flume.channel
 
ChannelSelectorFactory() - Constructor for class org.apache.flume.channel.ChannelSelectorFactory
 
ChannelSelectorType - Enum in org.apache.flume.conf.channel
Enumeration of built in channel selector types available in the system.
ChannelType - Enum in org.apache.flume.conf.channel
Enumeration of built in channel types available in the system.
ChannelUtils - Class in org.apache.flume.channel
A collection of utilities for interacting with Channel objects.
charset - Static variable in interface org.apache.flume.sink.elasticsearch.ElasticSearchEventSerializer
 
CHARSET - Static variable in class org.apache.flume.source.ExecSourceConfigurationConstants
Charset for reading input
CHARSET_CONFIG - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
What charset to use when serializing into HBase's byte arrays
CHARSET_DEFAULT - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
 
CHARSET_DFLT - Static variable in class org.apache.flume.serialization.LineDeserializer
 
CHECKPOINT_DIR - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
Directory Checkpoints will be written in
CHECKPOINT_INTERVAL - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
Interval at which checkpoints should be taken.
CHECKPOINTPOSITION_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
CheckpointRebuilder - Class in org.apache.flume.channel.file
 
CheckpointRebuilder(List<File>, FlumeEventQueue, boolean) - Constructor for class org.apache.flume.channel.file.CheckpointRebuilder
 
CHECKPOINTWRITEORDERID_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
CHECKSUM_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
CIPHER_PROVIDER - Static variable in class org.apache.flume.channel.file.encryption.EncryptionConfiguration
Encryption cipher provider, default is null.
CipherProvider - Class in org.apache.flume.channel.file.encryption
 
CipherProvider() - Constructor for class org.apache.flume.channel.file.encryption.CipherProvider
 
CipherProvider.Decryptor - Class in org.apache.flume.channel.file.encryption
 
CipherProvider.Decryptor() - Constructor for class org.apache.flume.channel.file.encryption.CipherProvider.Decryptor
 
CipherProvider.Decryptor.Builder<T extends CipherProvider.Decryptor> - Class in org.apache.flume.channel.file.encryption
Builder implementations MUST have a no-arg constructor
CipherProvider.Decryptor.Builder() - Constructor for class org.apache.flume.channel.file.encryption.CipherProvider.Decryptor.Builder
 
CipherProvider.Encryptor - Class in org.apache.flume.channel.file.encryption
 
CipherProvider.Encryptor() - Constructor for class org.apache.flume.channel.file.encryption.CipherProvider.Encryptor
 
CipherProvider.Encryptor.Builder<T extends CipherProvider.Encryptor> - Class in org.apache.flume.channel.file.encryption
Builder implementations MUST have a no-arg constructor
CipherProvider.Encryptor.Builder() - Constructor for class org.apache.flume.channel.file.encryption.CipherProvider.Encryptor.Builder
 
CIPHERPROVIDER_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
CipherProviderFactory - Class in org.apache.flume.channel.file.encryption
 
CipherProviderFactory() - Constructor for class org.apache.flume.channel.file.encryption.CipherProviderFactory
 
CipherProviderType - Enum in org.apache.flume.channel.file.encryption
 
clean(ByteBuffer) - Static method in class org.apache.flume.tools.DirectMemoryUtils
 
cleanUp() - Method in interface org.apache.flume.sink.hbase.AsyncHbaseEventSerializer
Clean up any state.
cleanUp() - Method in class org.apache.flume.sink.hbase.SimpleAsyncHbaseEventSerializer
 
clear() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
clear() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
 
clear() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
 
clear() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
 
clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
 
clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
 
clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
 
clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
 
clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
 
clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
 
clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
 
clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
 
clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback.Builder
 
clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
 
clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter.Builder
 
clear() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
 
clear() - Method in class org.apache.flume.Context
Removes all of the mappings from this map.
clear() - Method in class org.apache.flume.source.scribe.LogEntry
 
clear() - Method in class org.apache.flume.source.scribe.Scribe.Log_args
 
clear() - Method in class org.apache.flume.source.scribe.Scribe.Log_result
 
clear() - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
clear() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
 
clear() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
 
clear() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
clear() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
 
clearActiveLogs() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
repeated .ActiveLog activeLogs = 5;
clearBackupCheckpointPosition() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
optional sfixed64 backupCheckpointPosition = 6;
clearBackupCheckpointWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
optional sfixed64 backupCheckpointWriteOrderID = 7;
clearBody() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
required bytes body = 2;
clearCheckpointPosition() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
required sfixed64 checkpointPosition = 3;
clearCheckpointWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
required sfixed64 checkpointWriteOrderID = 4;
clearChecksum() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
optional sfixed64 checksum = 2;
clearCipherProvider() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
required string cipherProvider = 1;
clearCount() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
required sfixed32 count = 2;
clearEncryption() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
optional .LogFileEncryption encryption = 5;
clearEvent() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
required .FlumeEvent event = 1;
clearFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
required sfixed32 fileID = 1;
clearHeaders() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
repeated .FlumeEventHeader headers = 1;
clearKey() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
required string key = 1;
clearKeyAlias() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
required string keyAlias = 2;
clearLogFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
required sfixed32 logFileID = 1;
clearLogFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
required sfixed32 logFileID = 2;
clearOffset() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
required sfixed32 offset = 2;
clearParameters() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
optional bytes parameters = 3;
clearQueueHead() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
required sfixed32 queueHead = 4;
clearQueueSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
required sfixed32 queueSize = 3;
clearTransactionID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
required sfixed64 transactionID = 2;
clearType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
required sfixed32 type = 1;
clearType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
required sfixed32 type = 1;
clearValue() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
required string value = 2;
clearVersion() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
required sfixed32 version = 1;
clearVersion() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
required sfixed32 version = 1;
clearWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
required sfixed64 writeOrderID = 2;
clearWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
required sfixed64 writeOrderID = 3;
CLIENT_PREFIX - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
The client prefix to extract the configuration that will be passed to elasticsearch client.
CLIENT_TYPE - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
The client type used for sending bulks to ElasticSearch
Clock - Interface in org.apache.flume
Facade for System.currentTimeMillis for Testing
clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
 
clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
 
clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
 
clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
 
clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
 
clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
 
clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
 
clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
 
clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback.Builder
 
clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
 
clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter.Builder
 
clone() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
 
close(AsyncMethodCallback<ThriftFlumeEventServer.AsyncClient.close_call>) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient
 
close(AsyncMethodCallback<ThriftFlumeEventServer.AsyncClient.close_call>) - Method in interface com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncIface
 
close() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
 
close() - Method in interface com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Iface
 
close() - Method in class org.apache.flume.api.AbstractRpcClient
 
close() - Method in class org.apache.flume.api.FailoverRpcClient
Close the connection.
close() - Method in class org.apache.flume.api.LoadBalancingRpcClient
 
close() - Method in class org.apache.flume.api.NettyAvroRpcClient
 
close() - Method in interface org.apache.flume.api.RpcClient
Immediately closes the client so that it may no longer be used.
close() - Method in class org.apache.flume.api.ThriftRpcClient
 
close() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
close() - Method in class org.apache.flume.channel.ChannelProcessor
 
close() - Method in class org.apache.flume.channel.file.LogFile.OperationRecordUpdater
 
close() - Method in class org.apache.flume.channel.file.LogFile.SequentialReader
 
close() - Method in class org.apache.flume.channel.jdbc.impl.JdbcChannelProviderImpl
 
close() - Method in class org.apache.flume.channel.jdbc.impl.JdbcTransactionImpl
 
close() - Method in interface org.apache.flume.channel.jdbc.JdbcChannelProvider
Deinitializes the channel provider.
close() - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel.NoOpTransaction
 
close() - Method in interface org.apache.flume.client.avro.EventReader
Clean-up any state associated with this reader.
close() - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader
 
close() - Method in class org.apache.flume.client.avro.SimpleTextLineEventReader
 
close() - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
Closes underlying client.
close() - Method in class org.apache.flume.interceptor.HostInterceptor
 
close() - Method in interface org.apache.flume.interceptor.Interceptor
Perform any closing / shutdown needed by the Interceptor.
close() - Method in class org.apache.flume.interceptor.InterceptorChain
 
close() - Method in class org.apache.flume.interceptor.RegexExtractorInterceptor
 
close() - Method in class org.apache.flume.interceptor.RegexFilteringInterceptor
 
close() - Method in class org.apache.flume.interceptor.StaticInterceptor
 
close() - Method in class org.apache.flume.interceptor.TimestampInterceptor
 
close() - Method in class org.apache.flume.serialization.AvroEventDeserializer
 
close() - Method in class org.apache.flume.serialization.DurablePositionTracker
 
close() - Method in interface org.apache.flume.serialization.EventDeserializer
Calls EventDeserializer.reset() on the stream and then closes it.
close() - Method in class org.apache.flume.serialization.LineDeserializer
 
close() - Method in interface org.apache.flume.serialization.PositionTracker
 
close() - Method in class org.apache.flume.serialization.ResettableFileInputStream
 
close() - Method in class org.apache.flume.serialization.ResettableInputStream
 
close() - Method in interface org.apache.flume.sink.elasticsearch.client.ElasticSearchClient
Close connection to elastic search in client
close() - Method in class org.apache.flume.sink.elasticsearch.client.ElasticSearchRestClient
 
close() - Method in class org.apache.flume.sink.elasticsearch.client.ElasticSearchTransportClient
 
close() - Method in interface org.apache.flume.sink.hbase.HbaseEventSerializer
 
close() - Method in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
 
close() - Method in class org.apache.flume.sink.hbase.SimpleHbaseEventSerializer
 
close() - Method in class org.apache.flume.sink.hdfs.HDFSCompressedDataStream
 
close() - Method in class org.apache.flume.sink.hdfs.HDFSDataStream
 
close() - Method in class org.apache.flume.sink.hdfs.HDFSSequenceFile
 
close() - Method in interface org.apache.flume.sink.hdfs.HDFSWriter
 
close() - Method in class org.apache.flume.sink.solr.morphline.BlobDeserializer
 
close() - Method in class org.apache.flume.sink.solr.morphline.MorphlineInterceptor
 
close() - Method in class org.apache.flume.sink.solr.morphline.UUIDInterceptor
 
close() - Method in interface org.apache.flume.Transaction
Ends a transaction boundary for the current channel operation.
CLUSTER_NAME - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
Name of the ElasticSearch cluster to connect to
COL_NAME_CONFIG - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
Comma separated list of column names to place matching groups in.
collectorRunnable - Variable in class org.apache.flume.instrumentation.GangliaServer
 
COLUMN_LOOKUP_QUERY - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
COLUMN_NAME_DEFAULT - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
 
com.cloudera.flume.handlers.thrift - package com.cloudera.flume.handlers.thrift
 
commit() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
commit() - Method in class org.apache.flume.channel.jdbc.impl.JdbcTransactionImpl
 
commit() - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel.NoOpTransaction
 
commit() - Method in interface org.apache.flume.client.avro.ReliableEventReader
Indicate to the implementation that the previously-returned events have been successfully processed and committed.
commit() - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader
Commit the last lines which were read.
commit() - Method in interface org.apache.flume.Transaction
Indicates that the transaction can be successfully committed.
commitTransaction() - Method in interface org.apache.flume.sink.solr.morphline.MorphlineHandler
Sends any outstanding documents to Solr and waits for a positive or negative ack (i.e.
commitTransaction() - Method in class org.apache.flume.sink.solr.morphline.MorphlineHandlerImpl
 
compareTo(ThriftFlumeEvent) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
compareTo(ThriftFlumeEventServer.append_args) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
 
compareTo(ThriftFlumeEventServer.close_args) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
 
compareTo(ThriftFlumeEventServer.close_result) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
 
compareTo(LogRecord) - Method in class org.apache.flume.channel.file.LogRecord
 
compareTo(LogEntry) - Method in class org.apache.flume.source.scribe.LogEntry
 
compareTo(Scribe.Log_args) - Method in class org.apache.flume.source.scribe.Scribe.Log_args
 
compareTo(Scribe.Log_result) - Method in class org.apache.flume.source.scribe.Scribe.Log_result
 
compareTo(ThriftFlumeEvent) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
compareTo(ThriftSourceProtocol.append_args) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
 
compareTo(ThriftSourceProtocol.append_result) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
 
compareTo(ThriftSourceProtocol.appendBatch_args) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
compareTo(ThriftSourceProtocol.appendBatch_result) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
 
completedSuffix(String) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
 
ComponentConfiguration - Class in org.apache.flume.conf
Abstract implementation of the Component Configuration Manager.
ComponentConfiguration(String) - Constructor for class org.apache.flume.conf.ComponentConfiguration
 
ComponentConfiguration.ComponentType - Enum in org.apache.flume.conf
 
ComponentConfigurationFactory - Class in org.apache.flume.conf
 
ComponentConfigurationFactory() - Constructor for class org.apache.flume.conf.ComponentConfigurationFactory
 
componentName - Variable in class org.apache.flume.conf.ComponentConfiguration
 
COMPRESSION_CODEC - Static variable in class org.apache.flume.serialization.AvroEventSerializerConfigurationConstants
Avro compression codec.
CONF_HOSTS - Variable in class org.apache.flume.instrumentation.GangliaServer
 
CONF_ISGANGLIA3 - Variable in class org.apache.flume.instrumentation.GangliaServer
 
CONF_MONITOR_CLASS - Static variable in class org.apache.flume.node.Application
 
CONF_MONITOR_PREFIX - Static variable in class org.apache.flume.node.Application
 
CONF_POLL_FREQUENCY - Variable in class org.apache.flume.instrumentation.GangliaServer
 
CONFIG_ACKEVENT - Static variable in class org.apache.flume.source.NetcatSourceConfigurationConstants
Ack every event received with an "OK" back to the sender
CONFIG_BACKOFF - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
 
CONFIG_BACKOFF - Static variable in class org.apache.flume.sink.LoadBalancingSinkProcessor
 
CONFIG_BATCH_SIZE - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
Configuration key used to specify the batch size.
CONFIG_BATCH_SIZE - Static variable in class org.apache.flume.source.ExecSourceConfigurationConstants
Number of lines to read at a time
CONFIG_BATCH_TIME_OUT - Static variable in class org.apache.flume.source.ExecSourceConfigurationConstants
Amount of time to wait, if the buffer size was not reached, before to data is pushed downstream: : default 3000 ms
CONFIG_BATCHSIZE - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
Maximum number of events the sink should take from the channel per transaction, if available.
CONFIG_BATCHSIZE - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
 
CONFIG_BIND - Static variable in class org.apache.flume.source.http.HTTPSourceConfigurationConstants
 
CONFIG_BIND - Static variable in class org.apache.flume.source.ThriftSource
Config param for the hostname to listen on.
CONFIG_CHANNEL - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
 
CONFIG_CHANNELS - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
 
CONFIG_CHANNELS_PREFIX - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
 
CONFIG_CHARSET - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
 
CONFIG_CLIENT_TYPE - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
Configuration key to specify the RpcClient type to be used.
CONFIG_COALESCE_INCREMENTS - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
 
CONFIG_COLUMN_FAMILY - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
The column family which the sink should use.
CONFIG_COMPRESSION_LEVEL - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
 
CONFIG_COMPRESSION_TYPE - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
The following are const for the NettyAvro Client.
CONFIG_CONFIG - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
 
CONFIG_CONNECT_TIMEOUT - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
Configuration key to specify connection timeout in milliseconds.
CONFIG_CONNECTION_POOL_SIZE - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
Maximum number of connections each Thrift Rpc client can open to a given host.
CONFIG_CREATE_FK - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_CREATE_INDEX - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_CREATE_SCHEMA - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_DATABASE_TYPE - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_DATEFORMAT - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
 
CONFIG_DEFAULT_CHANNEL - Static variable in class org.apache.flume.channel.MultiplexingChannelSelector
 
CONFIG_ENABLE_WAL - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
 
CONFIG_EVENTSIZE - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
Maximum allowable size of events.
CONFIG_FORMAT_PREFIX - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
 
CONFIG_HANDLER - Static variable in class org.apache.flume.source.http.HTTPSourceConfigurationConstants
 
CONFIG_HANDLER_PREFIX - Static variable in class org.apache.flume.source.http.HTTPSourceConfigurationConstants
 
CONFIG_HOST - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
 
CONFIG_HOST_SELECTOR - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
The selector type used by the LoadBalancingRpcClient.
CONFIG_HOSTNAME - Static variable in class org.apache.flume.source.NetcatSourceConfigurationConstants
Hostname to bind to.
CONFIG_HOSTS - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
Hosts configuration key to specify a space delimited list of named hosts.
CONFIG_HOSTS_PREFIX - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
Hosts prefix to specify address of a particular named host.
CONFIG_JDBC_DRIVER_CLASS - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_JDBC_PROPS_FILE - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_JDBC_SYSPROP_PREFIX - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_KEEP_FIELDS - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
 
CONFIG_KEYTAB - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
 
CONFIG_LOG_STDERR - Static variable in class org.apache.flume.source.ExecSourceConfigurationConstants
Should stderr from the command be logged: default false
CONFIG_MAX_ATTEMPTS - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
Maximum attempts to be made by the FailoverRpcClient in case of failures.
CONFIG_MAX_BACKOFF - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
 
CONFIG_MAX_CAPACITY - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_MAX_CONNECTIONS - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_MAX_LINE_LENGTH - Static variable in class org.apache.flume.source.NetcatSourceConfigurationConstants
Maximum line length per event.
CONFIG_MULTIPLEX_HEADER_NAME - Static variable in class org.apache.flume.channel.MultiplexingChannelSelector
 
CONFIG_NUMPROCESSORS - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
Number of processors used to calculate number of threads to spawn.
CONFIG_OPTIONAL - Static variable in class org.apache.flume.channel.ReplicatingChannelSelector
Configuration to set a subset of the channels as optional.
CONFIG_PASSWORD - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_PORT - Static variable in class org.apache.flume.instrumentation.http.HTTPMetricsServer
 
CONFIG_PORT - Static variable in class org.apache.flume.source.http.HTTPSourceConfigurationConstants
 
CONFIG_PORT - Static variable in class org.apache.flume.source.NetcatSourceConfigurationConstants
Port to bind to.
CONFIG_PORT - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
 
CONFIG_PORT - Static variable in class org.apache.flume.source.ThriftSource
Config param for the port to listen on.
CONFIG_PORT_CHARSET_PREFIX - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
 
CONFIG_PORT_HEADER - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
 
CONFIG_PORTS - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
List of ports to listen to.
CONFIG_PREFIX_MAPPING - Static variable in class org.apache.flume.channel.MultiplexingChannelSelector
 
CONFIG_PREFIX_OPTIONAL - Static variable in class org.apache.flume.channel.MultiplexingChannelSelector
 
CONFIG_PRINCIPAL - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
 
CONFIG_READBUF_SIZE - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
 
CONFIG_REGEX - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
 
CONFIG_REPLACE - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
 
CONFIG_REQUEST_TIMEOUT - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
Configuration key to specify request timeout in milliseconds.
CONFIG_RESTART - Static variable in class org.apache.flume.source.ExecSourceConfigurationConstants
Should the exec'ed command restarted if it dies: : default false
CONFIG_RESTART_THROTTLE - Static variable in class org.apache.flume.source.ExecSourceConfigurationConstants
Amount of time to wait before attempting a restart: : default 10000 ms
CONFIG_SCHEMA_TYPE_KEY - Static variable in class org.apache.flume.serialization.AvroEventDeserializer
 
CONFIG_SEARCH - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
 
CONFIG_SELECTOR - Static variable in class org.apache.flume.sink.LoadBalancingSinkProcessor
 
CONFIG_SELECTOR_PREFIX - Static variable in class org.apache.flume.sink.LoadBalancingSinkProcessor
 
CONFIG_SERIALIZER - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
The fully qualified class name of the serializer the sink should use.
CONFIG_SERIALIZER_PREFIX - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
Configuration to pass to the serializer.
CONFIG_SHELL - Static variable in class org.apache.flume.source.ExecSourceConfigurationConstants
Optional shell/command processor used to run command
CONFIG_SINK_PROCESSOR_PREFIX - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
 
CONFIG_SINKGROUPS - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
 
CONFIG_SINKGROUPS_PREFIX - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
 
CONFIG_SINKS - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
 
CONFIG_SINKS_PREFIX - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
 
CONFIG_SOURCE_CHANNELSELECTOR_PREFIX - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
 
CONFIG_SOURCES - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
 
CONFIG_SOURCES_PREFIX - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
 
CONFIG_SSL - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
Configuration constants for SSL support
CONFIG_TABLE - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
The Hbase table which the sink should write to.
CONFIG_THREADS - Static variable in class org.apache.flume.source.ThriftSource
Config param for the maximum number of threads this source should use to handle incoming data.
CONFIG_TIMEOUT - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
 
CONFIG_TRUST_ALL_CERTS - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
 
CONFIG_TRUSTSTORE - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
 
CONFIG_TRUSTSTORE_PASSWORD - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
 
CONFIG_TRUSTSTORE_TYPE - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
 
CONFIG_TX_ISOLATION_LEVEL - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_TYPE - Static variable in class org.apache.flume.conf.BasicConfigurationConstants
 
CONFIG_URL - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_USERNAME - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
Configurable - Interface in org.apache.flume.conf
Any class marked as Configurable may have a context including its sub-configuration passed to it, requesting it configure itself.
ConfigurableComponent - Interface in org.apache.flume.conf
 
Configurables - Class in org.apache.flume.conf
Methods for working with Configurables.
Configurables() - Constructor for class org.apache.flume.conf.Configurables
 
ConfigurationConstants - Class in org.apache.flume.channel.jdbc
Contains configuration keys used by the JDBC channel implementation.
ConfigurationException - Exception in org.apache.flume.conf
 
ConfigurationException(String) - Constructor for exception org.apache.flume.conf.ConfigurationException
 
ConfigurationException(Throwable) - Constructor for exception org.apache.flume.conf.ConfigurationException
 
ConfigurationException(String, Throwable) - Constructor for exception org.apache.flume.conf.ConfigurationException
 
ConfigurationProvider - Interface in org.apache.flume.node
 
configure(Map<String, String>) - Method in class org.apache.flume.agent.embedded.EmbeddedAgent
Configures the embedded agent.
configure(Context) - Method in class org.apache.flume.agent.embedded.EmbeddedSource
 
configure(Properties) - Method in class org.apache.flume.api.AbstractRpcClient
Configure the client using the given properties object.
configure(Properties) - Method in class org.apache.flume.api.FailoverRpcClient
 
configure(Properties) - Method in class org.apache.flume.api.LoadBalancingRpcClient
 
configure(Properties) - Method in class org.apache.flume.api.NettyAvroRpcClient
Configure the actual client using the properties.
configure(Properties) - Method in class org.apache.flume.api.ThriftRpcClient
 
configure(Context) - Method in class org.apache.flume.channel.AbstractChannel
 
configure(Context) - Method in class org.apache.flume.channel.ChannelProcessor
The Context of the associated Source is passed.
configure(Context) - Method in class org.apache.flume.channel.file.FileChannel
 
configure(Context) - Method in class org.apache.flume.channel.jdbc.JdbcChannel
 
configure(Context) - Method in class org.apache.flume.channel.MemoryChannel
Read parameters from context capacity = type long that defines the total number of events allowed at one time in the queue.
configure(Context) - Method in class org.apache.flume.channel.MultiplexingChannelSelector
 
configure(Context) - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel
 
configure(Context) - Method in class org.apache.flume.channel.ReplicatingChannelSelector
 
configure(Context) - Method in class org.apache.flume.channel.SpillableMemoryChannel
Read parameters from context memoryCapacity = total number of events allowed at one time in the memory queue.
configure(Context) - Method in class org.apache.flume.conf.channel.ChannelConfiguration
 
configure(Context) - Method in class org.apache.flume.conf.channel.ChannelSelectorConfiguration
 
configure(Context) - Method in class org.apache.flume.conf.ComponentConfiguration
 
configure(Context) - Method in interface org.apache.flume.conf.Configurable
Request the implementing class to (re)configure itself.
configure(ComponentConfiguration) - Method in interface org.apache.flume.conf.ConfigurableComponent
 
configure(Object, Context) - Static method in class org.apache.flume.conf.Configurables
Check that target implements Configurable and, if so, ask it to configure itself using the supplied context.
configure(Object, ComponentConfiguration) - Static method in class org.apache.flume.conf.Configurables
 
configure(Context) - Method in class org.apache.flume.conf.sink.SinkConfiguration
 
configure(Context) - Method in class org.apache.flume.conf.sink.SinkGroupConfiguration
 
configure(Context) - Method in class org.apache.flume.conf.sink.SinkProcessorConfiguration
 
configure(Context) - Method in class org.apache.flume.conf.source.SourceConfiguration
 
configure(Context) - Method in class org.apache.flume.instrumentation.GangliaServer
 
configure(Context) - Method in class org.apache.flume.instrumentation.http.HTTPMetricsServer
 
configure(Context) - Method in class org.apache.flume.interceptor.HostInterceptor.Builder
 
configure(Context) - Method in class org.apache.flume.interceptor.RegexExtractorInterceptor.Builder
 
configure(Context) - Method in class org.apache.flume.interceptor.RegexExtractorInterceptorMillisSerializer
 
configure(ComponentConfiguration) - Method in class org.apache.flume.interceptor.RegexExtractorInterceptorMillisSerializer
 
configure(Context) - Method in class org.apache.flume.interceptor.RegexExtractorInterceptorPassThroughSerializer
 
configure(ComponentConfiguration) - Method in class org.apache.flume.interceptor.RegexExtractorInterceptorPassThroughSerializer
 
configure(Context) - Method in class org.apache.flume.interceptor.RegexFilteringInterceptor.Builder
 
configure(Context) - Method in class org.apache.flume.interceptor.StaticInterceptor.Builder
 
configure(Context) - Method in class org.apache.flume.interceptor.TimestampInterceptor.Builder
 
configure(Context) - Method in class org.apache.flume.serialization.AbstractAvroEventSerializer
 
configure(Context) - Method in class org.apache.flume.sink.AbstractRpcSink
 
configure(Context) - Method in class org.apache.flume.sink.AbstractSinkSelector
 
configure(Context) - Method in class org.apache.flume.sink.DefaultSinkProcessor
 
configure(ComponentConfiguration) - Method in class org.apache.flume.sink.DefaultSinkProcessor
 
configure(Context) - Method in class org.apache.flume.sink.elasticsearch.AbstractElasticSearchIndexRequestBuilderFactory
 
configure(ComponentConfiguration) - Method in class org.apache.flume.sink.elasticsearch.AbstractElasticSearchIndexRequestBuilderFactory
 
configure(Context) - Method in class org.apache.flume.sink.elasticsearch.client.ElasticSearchRestClient
 
configure(Context) - Method in class org.apache.flume.sink.elasticsearch.client.ElasticSearchTransportClient
 
configure(Context) - Method in class org.apache.flume.sink.elasticsearch.ElasticSearchDynamicSerializer
 
configure(ComponentConfiguration) - Method in class org.apache.flume.sink.elasticsearch.ElasticSearchDynamicSerializer
 
configure(Context) - Method in class org.apache.flume.sink.elasticsearch.ElasticSearchLogStashEventSerializer
 
configure(ComponentConfiguration) - Method in class org.apache.flume.sink.elasticsearch.ElasticSearchLogStashEventSerializer
 
configure(Context) - Method in class org.apache.flume.sink.elasticsearch.ElasticSearchSink
 
configure(Context) - Method in class org.apache.flume.sink.elasticsearch.EventSerializerIndexRequestBuilderFactory
 
configure(ComponentConfiguration) - Method in class org.apache.flume.sink.elasticsearch.EventSerializerIndexRequestBuilderFactory
 
configure(Context) - Method in class org.apache.flume.sink.elasticsearch.SimpleIndexNameBuilder
 
configure(ComponentConfiguration) - Method in class org.apache.flume.sink.elasticsearch.SimpleIndexNameBuilder
 
configure(Context) - Method in class org.apache.flume.sink.elasticsearch.TimeBasedIndexNameBuilder
 
configure(ComponentConfiguration) - Method in class org.apache.flume.sink.elasticsearch.TimeBasedIndexNameBuilder
 
configure(Context) - Method in class org.apache.flume.sink.FailoverSinkProcessor
 
configure(Context) - Method in class org.apache.flume.sink.hbase.AsyncHBaseSink
 
configure(Context) - Method in class org.apache.flume.sink.hbase.HBaseSink
 
configure(Context) - Method in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
 
configure(ComponentConfiguration) - Method in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
 
configure(Context) - Method in class org.apache.flume.sink.hbase.SimpleAsyncHbaseEventSerializer
 
configure(ComponentConfiguration) - Method in class org.apache.flume.sink.hbase.SimpleAsyncHbaseEventSerializer
 
configure(Context) - Method in class org.apache.flume.sink.hbase.SimpleHbaseEventSerializer
 
configure(ComponentConfiguration) - Method in class org.apache.flume.sink.hbase.SimpleHbaseEventSerializer
 
configure(Context) - Method in class org.apache.flume.sink.hdfs.AbstractHDFSWriter
 
configure(Context) - Method in class org.apache.flume.sink.hdfs.AvroEventSerializer
 
configure(Context) - Method in class org.apache.flume.sink.hdfs.HDFSCompressedDataStream
 
configure(Context) - Method in class org.apache.flume.sink.hdfs.HDFSDataStream
 
configure(Context) - Method in class org.apache.flume.sink.hdfs.HDFSEventSink
 
configure(Context) - Method in class org.apache.flume.sink.hdfs.HDFSSequenceFile
 
configure(Context) - Method in class org.apache.flume.sink.irc.IRCSink
 
configure(Context) - Method in class org.apache.flume.sink.LoadBalancingSinkProcessor
 
configure(Context) - Method in class org.apache.flume.sink.NullSink
 
configure(Context) - Method in class org.apache.flume.sink.RollingFileSink
 
configure(Context) - Method in class org.apache.flume.sink.SinkGroup
 
configure(ComponentConfiguration) - Method in class org.apache.flume.sink.SinkGroup
 
configure(Context) - Method in class org.apache.flume.sink.solr.morphline.BlobHandler
 
configure(Context) - Method in class org.apache.flume.sink.solr.morphline.MorphlineHandlerImpl
 
configure(Context) - Method in class org.apache.flume.sink.solr.morphline.MorphlineInterceptor.Builder
 
configure(Context) - Method in class org.apache.flume.sink.solr.morphline.MorphlineSink
 
configure(Context) - Method in class org.apache.flume.sink.solr.morphline.MorphlineSolrSink
 
configure(Context) - Method in class org.apache.flume.sink.solr.morphline.UUIDInterceptor.Builder
 
configure(Context) - Method in class org.apache.flume.source.avroLegacy.AvroLegacySource
 
configure(Context) - Method in class org.apache.flume.source.AvroSource
 
configure(Context) - Method in class org.apache.flume.source.BasicSourceSemantics
 
configure(Context) - Method in class org.apache.flume.source.ExecSource
 
configure(Context) - Method in class org.apache.flume.source.http.HTTPSource
 
configure(Context) - Method in class org.apache.flume.source.http.JSONHandler
 
configure(Context) - Method in class org.apache.flume.source.MultiportSyslogTCPSource
 
configure(Context) - Method in class org.apache.flume.source.NetcatSource
 
configure(Context) - Method in class org.apache.flume.source.scribe.ScribeSource
 
configure(Context) - Method in class org.apache.flume.source.SequenceGeneratorSource
Read parameters from context batchSize = type int that defines the size of event batches
configure(Context) - Method in class org.apache.flume.source.SpoolDirectorySource
 
configure(Context) - Method in class org.apache.flume.source.StressSource
Read parameters from context -maxTotalEvents = type long that defines the total number of events to be sent -maxSuccessfulEvents = type long that defines the total number of events to be sent -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
configure(Context) - Method in class org.apache.flume.source.SyslogTcpSource
 
configure(Context) - Method in class org.apache.flume.source.SyslogUDPSource
 
configure(Context) - Method in class org.apache.flume.source.thriftLegacy.ThriftLegacySource
 
configure(Context) - Method in class org.apache.flume.source.ThriftSource
 
configure(Context) - Method in class org.apache.flume.source.twitter.TwitterSource
 
configured - Variable in class org.apache.flume.conf.ComponentConfiguration
 
CONNECTION_FACTORY - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
CONNECTION_FACTORY_DEFAULT - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
connectTimeout - Variable in class org.apache.flume.api.AbstractRpcClient
 
Constants - Class in org.apache.flume
 
CONSUME_ORDER - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
 
consumeOrder(SpoolDirectorySourceConfigurationConstants.ConsumeOrder) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
 
containsTag(String) - Static method in class org.apache.flume.formatter.output.BucketPath
Deprecated.
ContentBuilderUtil - Class in org.apache.flume.sink.elasticsearch
Utility methods for using ElasticSearch XContentBuilder
Context - Class in org.apache.flume
The context is a key-value store used to pass configuration information throughout the system.
Context() - Constructor for class org.apache.flume.Context
 
Context(Map<String, String>) - Constructor for class org.apache.flume.Context
 
convert(Event) - Method in class org.apache.flume.serialization.AbstractAvroEventSerializer
Simple conversion routine used to convert an Event to a type of your choosing.
convert(Event) - Method in class org.apache.flume.serialization.FlumeEventAvroEventSerializer
A no-op for this simple, special-case implementation
convert(Message) - Method in class org.apache.flume.source.jms.DefaultJMSMessageConverter
 
convert(Message) - Method in interface org.apache.flume.source.jms.JMSMessageConverter
 
CONVERTER - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
CONVERTER_CHARSET - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
CONVERTER_CHARSET_DEFAULT - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
CONVERTER_TYPE - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
CONVERTER_TYPE_DEFAULT - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
copyFile(File, File) - Static method in class org.apache.flume.channel.file.Serialization
Copy a file using a 64K size buffer.
CorruptEventException - Exception in org.apache.flume.channel.file
 
CorruptEventException() - Constructor for exception org.apache.flume.channel.file.CorruptEventException
 
CorruptEventException(String) - Constructor for exception org.apache.flume.channel.file.CorruptEventException
 
CorruptEventException(String, Throwable) - Constructor for exception org.apache.flume.channel.file.CorruptEventException
 
COUNT_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
CounterGroup - Class in org.apache.flume
Used for counting events, collecting metrics, etc.
CounterGroup() - Constructor for class org.apache.flume.CounterGroup
 
create(List<Channel>, Map<String, String>) - Static method in class org.apache.flume.channel.ChannelSelectorFactory
 
create(List<Channel>, ChannelSelectorConfiguration) - Static method in class org.apache.flume.channel.ChannelSelectorFactory
 
create(String, String) - Method in class org.apache.flume.channel.DefaultChannelFactory
 
create(String, String) - Method in interface org.apache.flume.ChannelFactory
 
create(String, String, ComponentConfiguration.ComponentType) - Static method in class org.apache.flume.conf.ComponentConfigurationFactory
 
create(String, String) - Method in class org.apache.flume.sink.DefaultSinkFactory
 
create(String, String) - Method in interface org.apache.flume.SinkFactory
 
create(String, String) - Method in class org.apache.flume.source.DefaultSourceFactory
 
create(Properties) - Method in class org.apache.flume.source.jms.InitialContextFactory
 
create(String, String) - Method in interface org.apache.flume.SourceFactory
 
createGangliaMessage(String, String) - Method in class org.apache.flume.instrumentation.GangliaServer
 
createGangliaMessage31(String, String) - Method in class org.apache.flume.instrumentation.GangliaServer
 
createHostIterator() - Method in interface org.apache.flume.api.LoadBalancingRpcClient.HostSelector
 
createIndexRequest(Client, String, String, Event) - Method in class org.apache.flume.sink.elasticsearch.AbstractElasticSearchIndexRequestBuilderFactory
Creates and prepares an IndexRequestBuilder from the supplied Client via delegation to the subclass-hook template methods AbstractElasticSearchIndexRequestBuilderFactory.getIndexName(String, long) and AbstractElasticSearchIndexRequestBuilderFactory.prepareIndexRequest(IndexRequestBuilder, String, String, Event)
createIndexRequest(Client, String, String, Event) - Method in interface org.apache.flume.sink.elasticsearch.ElasticSearchIndexRequestBuilderFactory
 
createIterator() - Method in class org.apache.flume.util.OrderSelector
 
createIterator() - Method in class org.apache.flume.util.RandomOrderSelector
 
createIterator() - Method in class org.apache.flume.util.RoundRobinOrderSelector
 
createSchemaObjects(boolean, boolean) - Method in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
createSchemaObjects(boolean, boolean) - Method in class org.apache.flume.channel.jdbc.impl.MySQLSchemaHandler
 
createSchemaObjects(boolean, boolean) - Method in interface org.apache.flume.channel.jdbc.impl.SchemaHandler
Creates the schema.
createSinkIterator() - Method in interface org.apache.flume.sink.LoadBalancingSinkProcessor.SinkSelector
 
createTransaction() - Method in class org.apache.flume.channel.BasicChannelSemantics
Called to create new Transaction objects, which must extend BasicTransactionSemantics.
createTransaction() - Method in class org.apache.flume.channel.file.FileChannel
 
createTransaction() - Method in class org.apache.flume.channel.MemoryChannel
 
createTransaction() - Method in class org.apache.flume.channel.SpillableMemoryChannel
 
CTX_PREFIX - Static variable in interface org.apache.flume.serialization.EventSerializer
Context prefix
currentTimeMillis() - Method in interface org.apache.flume.Clock
 
currentTimeMillis() - Method in class org.apache.flume.SystemClock
 

D

DATA_DIRS - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
Directories data files will be written in.
DatabaseType - Enum in org.apache.flume.channel.jdbc
 
DATE_FORMAT - Static variable in class org.apache.flume.sink.elasticsearch.TimeBasedIndexNameBuilder
 
DECODE_ERROR_POLICY - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
What to do when there is a character set decoding error.
decodeErrorPolicy(DecodeErrorPolicy) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
 
DecodeErrorPolicy - Enum in org.apache.flume.serialization
 
decrypt(byte[]) - Method in class org.apache.flume.channel.file.encryption.CipherProvider.Decryptor
 
DecryptionFailureException - Exception in org.apache.flume.channel.file.encryption
Exception that is thrown when the channel is unable to decrypt an even read from the channel.
DecryptionFailureException(String) - Constructor for exception org.apache.flume.channel.file.encryption.DecryptionFailureException
 
DecryptionFailureException(String, Throwable) - Constructor for exception org.apache.flume.channel.file.encryption.DecryptionFailureException
 
deepCopy() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
deepCopy() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
 
deepCopy() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
 
deepCopy() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
 
deepCopy() - Method in class org.apache.flume.source.scribe.LogEntry
 
deepCopy() - Method in class org.apache.flume.source.scribe.Scribe.Log_args
 
deepCopy() - Method in class org.apache.flume.source.scribe.Scribe.Log_result
 
deepCopy() - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
deepCopy() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
 
deepCopy() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
 
deepCopy() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
deepCopy() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
 
DEFAULT_BACKOFF - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
 
DEFAULT_BASENAME_HEADER - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
 
DEFAULT_BASENAME_HEADER_KEY - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
 
DEFAULT_BATCH_SIZE - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
Default batch size.
DEFAULT_BATCH_SIZE - Static variable in class org.apache.flume.source.ExecSourceConfigurationConstants
 
DEFAULT_BATCH_SIZE - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
 
DEFAULT_BATCH_TIME_OUT - Static variable in class org.apache.flume.source.ExecSourceConfigurationConstants
 
DEFAULT_BATCHSIZE - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
 
DEFAULT_BIND - Static variable in class org.apache.flume.source.http.HTTPSourceConfigurationConstants
 
DEFAULT_BUF_SIZE - Static variable in class org.apache.flume.serialization.ResettableFileInputStream
 
DEFAULT_BUFFER_MAX_LINE_LENGTH - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
Deprecated.
DEFAULT_BUFFER_MAX_LINES - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
Deprecated.
DEFAULT_CAPACITY - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
 
DEFAULT_CHARSET - Static variable in class org.apache.flume.source.ExecSourceConfigurationConstants
 
DEFAULT_CHARSET - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
 
DEFAULT_CHECKPOINT_INTERVAL - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
 
DEFAULT_CLIENT_TYPE - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
The default client type to be created if no explicit type is specified.
DEFAULT_CLIENT_TYPE - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
 
DEFAULT_CLUSTER_NAME - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
 
DEFAULT_COALESCE_INCREMENTS - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
 
DEFAULT_COMPRESSION_CODEC - Static variable in class org.apache.flume.serialization.AvroEventSerializerConfigurationConstants
 
DEFAULT_COMPRESSION_LEVEL - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
 
DEFAULT_CONNECT_TIMEOUT_MILLIS - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
Default connection, handshake, and initial request timeout in milliseconds.
DEFAULT_CONNECTION_POOL_SIZE - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
 
DEFAULT_CONSUME_ORDER - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
 
DEFAULT_DATE_FORMAT - Static variable in class org.apache.flume.sink.elasticsearch.TimeBasedIndexNameBuilder
 
DEFAULT_DECODE_ERROR_POLICY - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
 
DEFAULT_DELETE_POLICY - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
 
DEFAULT_DESERIALIZER - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
 
DEFAULT_DMAX - Static variable in class org.apache.flume.instrumentation.GangliaServer
 
DEFAULT_ENABLE_WAL - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
 
DEFAULT_EXCLUDE_EVENTS - Static variable in class org.apache.flume.interceptor.RegexFilteringInterceptor.Constants
 
DEFAULT_FILE_HEADER - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
 
DEFAULT_FILENAME_HEADER_KEY - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
 
DEFAULT_FSYNC_INTERVAL - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
 
DEFAULT_FSYNC_PRE_TXN - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
 
DEFAULT_HANDLER - Static variable in class org.apache.flume.source.http.HTTPSourceConfigurationConstants
 
DEFAULT_IGNORE_PAT - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
 
DEFAULT_INDEX_NAME - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
 
DEFAULT_INDEX_NAME_BUILDER_CLASS - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
 
DEFAULT_INDEX_TYPE - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
 
DEFAULT_INITIAL_SIZE - Static variable in class org.apache.flume.source.SyslogUDPSource
 
DEFAULT_INPUT_CHARSET - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
 
DEFAULT_KEEP_ALIVE - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
 
DEFAULT_KEEP_FIELDS - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
 
DEFAULT_LOG_STDERR - Static variable in class org.apache.flume.source.ExecSourceConfigurationConstants
 
DEFAULT_MAX_BACKOFF - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
 
DEFAULT_MAX_FILE_SIZE - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
 
DEFAULT_MAX_LINE_LENGTH - Static variable in class org.apache.flume.source.NetcatSourceConfigurationConstants
 
DEFAULT_MIN_SIZE - Static variable in class org.apache.flume.source.SyslogUDPSource
 
DEFAULT_MINIMUM_REQUIRED_SPACE - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
Minimum space required defaults to 500MB
DEFAULT_MULTIPLEX_HEADER - Static variable in class org.apache.flume.channel.MultiplexingChannelSelector
 
DEFAULT_POLL_FREQUENCY - Variable in class org.apache.flume.instrumentation.GangliaServer
 
DEFAULT_PORT - Static variable in class org.apache.flume.instrumentation.http.HTTPMetricsServer
 
DEFAULT_PORT - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
DEFAULTS USED BY THE SINK
DEFAULT_PORT_HEADER - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
 
DEFAULT_READBUF_SIZE - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
 
DEFAULT_REGEX - Static variable in class org.apache.flume.interceptor.RegexFilteringInterceptor.Constants
 
DEFAULT_REQUEST_TIMEOUT_MILLIS - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
Default request timeout in milliseconds.
DEFAULT_RESTART - Static variable in class org.apache.flume.source.ExecSourceConfigurationConstants
 
DEFAULT_RESTART_THROTTLE - Static variable in class org.apache.flume.source.ExecSourceConfigurationConstants
 
DEFAULT_SERIALIZER_CLASS - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
 
DEFAULT_SIZE - Static variable in class org.apache.flume.source.SyslogUtils
 
DEFAULT_SLOPE - Static variable in class org.apache.flume.instrumentation.GangliaServer
 
DEFAULT_SPOOLED_FILE_SUFFIX - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
 
DEFAULT_SYNC_INTERVAL_BYTES - Static variable in class org.apache.flume.serialization.AvroEventSerializerConfigurationConstants
 
DEFAULT_TIME_ZONE - Static variable in class org.apache.flume.sink.elasticsearch.TimeBasedIndexNameBuilder
 
DEFAULT_TIMEOUT - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
 
DEFAULT_TMAX - Static variable in class org.apache.flume.instrumentation.GangliaServer
 
DEFAULT_TRACKER_DIR - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
 
DEFAULT_TRANSACTION_CAPACITY - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
 
DEFAULT_TTL - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
 
DEFAULT_UNITS - Static variable in class org.apache.flume.instrumentation.GangliaServer
 
DEFAULT_USE_DUAL_CHECKPOINTS - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
 
DEFAULT_USE_FAST_REPLAY - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
 
DEFAULT_USE_LOG_REPLAY_V1 - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
 
DEFAULT_ZK_ZNODE_PARENT - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
 
DefaultChannelFactory - Class in org.apache.flume.channel
 
DefaultChannelFactory() - Constructor for class org.apache.flume.channel.DefaultChannelFactory
 
DefaultJMSMessageConverter - Class in org.apache.flume.source.jms
Converts BytesMessage, TextMessage, and ObjectMessage to a Flume Event.
DefaultJMSMessageConverter.Builder - Class in org.apache.flume.source.jms
 
DefaultJMSMessageConverter.Builder() - Constructor for class org.apache.flume.source.jms.DefaultJMSMessageConverter.Builder
 
defaultMemoryCapacity - Static variable in class org.apache.flume.channel.SpillableMemoryChannel
 
defaultOverflowCapacity - Static variable in class org.apache.flume.channel.SpillableMemoryChannel
 
defaultOverflowDeactivationThreshold - Static variable in class org.apache.flume.channel.SpillableMemoryChannel
 
defaultOverflowTimeout - Static variable in class org.apache.flume.channel.SpillableMemoryChannel
 
DefaultSinkFactory - Class in org.apache.flume.sink
 
DefaultSinkFactory() - Constructor for class org.apache.flume.sink.DefaultSinkFactory
 
DefaultSinkProcessor - Class in org.apache.flume.sink
Default sink processor that only accepts a single sink, passing on process results without any additional handling.
DefaultSinkProcessor() - Constructor for class org.apache.flume.sink.DefaultSinkProcessor
 
DefaultSourceFactory - Class in org.apache.flume.source
 
DefaultSourceFactory() - Constructor for class org.apache.flume.source.DefaultSourceFactory
 
DELETE_POLICY - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
 
deletePolicy(String) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
 
DEPOSIT_HEADERS_CONFIG - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
Whether to deposit event headers into corresponding column qualifiers
DEPOSIT_HEADERS_DEFAULT - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
 
DerbySchemaHandler - Class in org.apache.flume.channel.jdbc.impl
Schema handler for Derby Database.
DerbySchemaHandler(DataSource) - Constructor for class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
DESERIALIZER - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
Deserializer to use to parse the file data into Flume Events
deserializerContext(Context) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
 
deserializerType(String) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
 
desiredState - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
DESTINATION_LOCATOR - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
DESTINATION_LOCATOR_DEFAULT - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
DESTINATION_NAME - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
DESTINATION_TYPE - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
DESTINATION_TYPE_QUEUE - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
DESTINATION_TYPE_TOPIC - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
df - Static variable in interface org.apache.flume.sink.elasticsearch.ElasticSearchIndexRequestBuilderFactory
 
DirectMemoryUtils - Class in org.apache.flume.tools
 
DirectMemoryUtils() - Constructor for class org.apache.flume.tools.DirectMemoryUtils
 
discard - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
Disposable - Annotation Type in org.apache.flume.annotations
 
doBegin() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
doClose() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
doCommit() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
doConfigure(Context) - Method in class org.apache.flume.source.BasicSourceSemantics
 
doConfigure(Context) - Method in class org.apache.flume.source.jms.JMSSource
 
doOpen(Configuration, Path, FileSystem) - Method in class org.apache.flume.sink.hdfs.HDFSDataStream
 
doProcess() - Method in class org.apache.flume.source.AbstractPollableSource
 
doProcess() - Method in class org.apache.flume.source.jms.JMSSource
 
doPut(Event) - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
doRollback() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
doStart() - Method in class org.apache.flume.source.BasicSourceSemantics
 
doStart() - Method in class org.apache.flume.source.jms.JMSSource
 
doStop() - Method in class org.apache.flume.source.BasicSourceSemantics
 
doStop() - Method in class org.apache.flume.source.jms.JMSSource
 
doTake() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
drainOrder - Variable in class org.apache.flume.channel.SpillableMemoryChannel
 
Dummy - Class in org.apache.flume
Placeholder class so the git mirror does not leave out the src/main/java dir
Dummy() - Constructor for class org.apache.flume.Dummy
 
dump() - Method in class org.apache.flume.channel.SpillableMemoryChannel.DrainOrderQueue
 
dumpEvent(Event) - Static method in class org.apache.flume.event.EventHelper
 
dumpEvent(Event, int) - Static method in class org.apache.flume.event.EventHelper
 
DurablePositionTracker - Class in org.apache.flume.serialization

Class that stores object state in an avro container file.

E

ElasticSearchClient - Interface in org.apache.flume.sink.elasticsearch.client
Interface for an ElasticSearch client which is responsible for sending bulks of events to ElasticSearch.
ElasticSearchClientFactory - Class in org.apache.flume.sink.elasticsearch.client
Internal ElasticSearch client factory.
ElasticSearchClientFactory() - Constructor for class org.apache.flume.sink.elasticsearch.client.ElasticSearchClientFactory
 
ElasticSearchDynamicSerializer - Class in org.apache.flume.sink.elasticsearch
Basic serializer that serializes the event body and header fields into individual fields
ElasticSearchDynamicSerializer() - Constructor for class org.apache.flume.sink.elasticsearch.ElasticSearchDynamicSerializer
 
ElasticSearchEventSerializer - Interface in org.apache.flume.sink.elasticsearch
Interface for an event serializer which serializes the headers and body of an event to write them to ElasticSearch.
ElasticSearchIndexRequestBuilderFactory - Interface in org.apache.flume.sink.elasticsearch
Interface for creating ElasticSearch IndexRequestBuilder instances from serialized flume events.
ElasticSearchLogStashEventSerializer - Class in org.apache.flume.sink.elasticsearch
Serialize flume events into the same format LogStash uses
ElasticSearchLogStashEventSerializer() - Constructor for class org.apache.flume.sink.elasticsearch.ElasticSearchLogStashEventSerializer
 
ElasticSearchRestClient - Class in org.apache.flume.sink.elasticsearch.client
Rest ElasticSearch client which is responsible for sending bulks of events to ElasticSearch using ElasticSearch HTTP API.
ElasticSearchRestClient(String[], ElasticSearchEventSerializer) - Constructor for class org.apache.flume.sink.elasticsearch.client.ElasticSearchRestClient
 
ElasticSearchRestClient(String[], ElasticSearchEventSerializer, HttpClient) - Constructor for class org.apache.flume.sink.elasticsearch.client.ElasticSearchRestClient
 
ElasticSearchSink - Class in org.apache.flume.sink.elasticsearch
A sink which reads events from a channel and writes them to ElasticSearch based on the work done by https://github.com/Aconex/elasticflume.git.
ElasticSearchSink() - Constructor for class org.apache.flume.sink.elasticsearch.ElasticSearchSink
Create an ElasticSearchSink configured using the supplied configuration
ElasticSearchSinkConstants - Class in org.apache.flume.sink.elasticsearch
 
ElasticSearchSinkConstants() - Constructor for class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
 
ElasticSearchTransportClient - Class in org.apache.flume.sink.elasticsearch.client
 
ElasticSearchTransportClient(String[], String, ElasticSearchEventSerializer) - Constructor for class org.apache.flume.sink.elasticsearch.client.ElasticSearchTransportClient
Transport client for external cluster
ElasticSearchTransportClient(String[], String, ElasticSearchIndexRequestBuilderFactory) - Constructor for class org.apache.flume.sink.elasticsearch.client.ElasticSearchTransportClient
 
ElasticSearchTransportClient(ElasticSearchIndexRequestBuilderFactory) - Constructor for class org.apache.flume.sink.elasticsearch.client.ElasticSearchTransportClient
Local transport client only for testing
ElasticSearchTransportClient(ElasticSearchEventSerializer) - Constructor for class org.apache.flume.sink.elasticsearch.client.ElasticSearchTransportClient
Local transport client only for testing
ElasticSearchTransportClient(Client, ElasticSearchEventSerializer) - Constructor for class org.apache.flume.sink.elasticsearch.client.ElasticSearchTransportClient
Used for testing
ElasticSearchTransportClient(Client, ElasticSearchIndexRequestBuilderFactory) - Constructor for class org.apache.flume.sink.elasticsearch.client.ElasticSearchTransportClient
Used for testing
EmbeddedAgent - Class in org.apache.flume.agent.embedded
EmbeddedAgent gives Flume users the ability to embed simple agents in applications.
EmbeddedAgent(String) - Constructor for class org.apache.flume.agent.embedded.EmbeddedAgent
 
EmbeddedAgentConfiguration - Class in org.apache.flume.agent.embedded
Stores publicly accessible configuration constants and private configuration constants and methods.
EmbeddedSource - Class in org.apache.flume.agent.embedded
Simple source used to allow direct access to the channel for the Embedded Agent.
EmbeddedSource() - Constructor for class org.apache.flume.agent.embedded.EmbeddedSource
 
encrypt(byte[]) - Method in class org.apache.flume.channel.file.encryption.CipherProvider.Encryptor
 
ENCRYPTION_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
ENCRYPTION_PREFIX - Static variable in class org.apache.flume.channel.file.encryption.EncryptionConfiguration
 
EncryptionConfiguration - Class in org.apache.flume.channel.file.encryption
 
enforceConstraints(Context) - Static method in class org.apache.flume.tools.HTTPServerConstraintUtil
Impose constraints on the Context passed in.
ensureOptionalNonNull(Context, String...) - Static method in class org.apache.flume.conf.Configurables
 
ensureRequiredNonNull(Context, String...) - Static method in class org.apache.flume.conf.Configurables
 
equals(Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
equals(ThriftFlumeEvent) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
equals(Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
 
equals(ThriftFlumeEventServer.append_args) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
 
equals(Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
 
equals(ThriftFlumeEventServer.close_args) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
 
equals(Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
 
equals(ThriftFlumeEventServer.close_result) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
 
equals(Object) - Method in class org.apache.flume.sink.hdfs.KerberosUser
 
equals(Object) - Method in class org.apache.flume.source.scribe.LogEntry
 
equals(LogEntry) - Method in class org.apache.flume.source.scribe.LogEntry
 
equals(Object) - Method in class org.apache.flume.source.scribe.Scribe.Log_args
 
equals(Scribe.Log_args) - Method in class org.apache.flume.source.scribe.Scribe.Log_args
 
equals(Object) - Method in class org.apache.flume.source.scribe.Scribe.Log_result
 
equals(Scribe.Log_result) - Method in class org.apache.flume.source.scribe.Scribe.Log_result
 
equals(Object) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
equals(ThriftFlumeEvent) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
equals(Object) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
 
equals(ThriftSourceProtocol.append_args) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
 
equals(Object) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
 
equals(ThriftSourceProtocol.append_result) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
 
equals(Object) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
equals(ThriftSourceProtocol.appendBatch_args) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
equals(Object) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
 
equals(ThriftSourceProtocol.appendBatch_result) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
 
error - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
ERROR_THRESHOLD - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
ERROR_THRESHOLD_DEFAULT - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
errors - Variable in class org.apache.flume.conf.ComponentConfiguration
 
escapeString(String, Map<String, String>) - Static method in class org.apache.flume.formatter.output.BucketPath
Replace all substrings of form %{tagname} with get(tagname).toString() and all shorthand substrings of form %x with a special value.
escapeString(String, Map<String, String>, boolean, int, int) - Static method in class org.apache.flume.formatter.output.BucketPath
A wrapper around BucketPath.escapeString(String, Map, TimeZone, boolean, int, int, boolean) with the timezone set to the default.
escapeString(String, Map<String, String>, TimeZone, boolean, int, int, boolean) - Static method in class org.apache.flume.formatter.output.BucketPath
Replace all substrings of form %{tagname} with get(tagname).toString() and all shorthand substrings of form %x with a special value.
Event - Interface in org.apache.flume
Basic representation of a data object in Flume.
event - Variable in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
 
EVENT_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
EVENT_STATUS - Static variable in class org.apache.flume.source.SyslogUtils
 
EventBuilder - Class in org.apache.flume.event
 
EventBuilder() - Constructor for class org.apache.flume.event.EventBuilder
 
EventDeliveryException - Exception in org.apache.flume
An event delivery exception is raised whenever an Event fails to reach at least one of its intended (next-hop) destinations.
EventDeliveryException() - Constructor for exception org.apache.flume.EventDeliveryException
 
EventDeliveryException(String) - Constructor for exception org.apache.flume.EventDeliveryException
 
EventDeliveryException(String, Throwable) - Constructor for exception org.apache.flume.EventDeliveryException
 
EventDeliveryException(Throwable) - Constructor for exception org.apache.flume.EventDeliveryException
 
EventDeserializer - Interface in org.apache.flume.serialization
Establishes a contract for reading events stored in arbitrary formats from reliable, resettable streams.
EventDeserializer.Builder - Interface in org.apache.flume.serialization
Knows how to construct this deserializer.
Note: Implementations MUST provide a public a no-arg constructor.
EventDeserializerFactory - Class in org.apache.flume.serialization
 
EventDeserializerFactory() - Constructor for class org.apache.flume.serialization.EventDeserializerFactory
 
EventDeserializerType - Enum in org.apache.flume.serialization
 
EventDrivenSource - Interface in org.apache.flume
A Source that does not need an external driver to poll for events to ingest; it provides its own event-driven mechanism to invoke event processing.
EventDrivenSourceRunner - Class in org.apache.flume.source
Starts, stops, and manages event-driven sources.
EventDrivenSourceRunner() - Constructor for class org.apache.flume.source.EventDrivenSourceRunner
 
EventFormatter - Interface in org.apache.flume.formatter.output
Deprecated.
EventHelper - Class in org.apache.flume.event
 
EventHelper() - Constructor for class org.apache.flume.event.EventHelper
 
EventReader - Interface in org.apache.flume.client.avro
A line reader produces a stream of lines for the AvroCLIClient to ingest into Flume.
events - Variable in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
EventSerDe - Interface in org.apache.flume.serialization

A class that is able to both serialize and deserialize events.

EventSerDe.Builder - Interface in org.apache.flume.serialization
Knows how to construct this serde.
Note: Implementations MUST provide a public a no-arg constructor.
EventSerializer - Interface in org.apache.flume.serialization
This interface provides callbacks for important serialization-related events.
EventSerializer.Builder - Interface in org.apache.flume.serialization
Knows how to construct this event serializer.
Note: Implementations MUST provide a public a no-arg constructor.
EventSerializerFactory - Class in org.apache.flume.serialization
 
EventSerializerFactory() - Constructor for class org.apache.flume.serialization.EventSerializerFactory
 
EventSerializerIndexRequestBuilderFactory - Class in org.apache.flume.sink.elasticsearch
Default implementation of ElasticSearchIndexRequestBuilderFactory.
EventSerializerIndexRequestBuilderFactory(ElasticSearchEventSerializer) - Constructor for class org.apache.flume.sink.elasticsearch.EventSerializerIndexRequestBuilderFactory
 
EventSerializerIndexRequestBuilderFactory(ElasticSearchEventSerializer, FastDateFormat) - Constructor for class org.apache.flume.sink.elasticsearch.EventSerializerIndexRequestBuilderFactory
 
EventSerializerType - Enum in org.apache.flume.serialization
 
EventStatus - Enum in com.cloudera.flume.handlers.thrift
 
evt - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
 
EXCLUDE_EVENTS - Static variable in class org.apache.flume.interceptor.RegexFilteringInterceptor.Constants
 
EXCLUDES - Static variable in class org.apache.flume.channel.file.Log
Set of files that should be excluded from backup and restores.
ExecSource - Class in org.apache.flume.source
A Source implementation that executes a Unix process and turns each line of text into an event.
ExecSource() - Constructor for class org.apache.flume.source.ExecSource
 
ExecSourceConfigurationConstants - Class in org.apache.flume.source
 
ExecSourceConfigurationConstants() - Constructor for class org.apache.flume.source.ExecSourceConfigurationConstants
 
execute() - Method in interface org.apache.flume.sink.elasticsearch.client.ElasticSearchClient
Sends bulk to the elasticsearch cluster
execute() - Method in class org.apache.flume.sink.elasticsearch.client.ElasticSearchRestClient
 
execute() - Method in class org.apache.flume.sink.elasticsearch.client.ElasticSearchTransportClient
 
expandShorthand(char) - Static method in class org.apache.flume.formatter.output.BucketPath
Deprecated.
extractEvent(ChannelBuffer) - Method in class org.apache.flume.source.SyslogUtils
 

F

fail() - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
 
failIfConfigured() - Method in class org.apache.flume.conf.ComponentConfiguration
 
FailoverRpcClient - Class in org.apache.flume.api
Avro/Netty implementation of RpcClient which supports failover.
FailoverRpcClient() - Constructor for class org.apache.flume.api.FailoverRpcClient
 
FailoverSinkProcessor - Class in org.apache.flume.sink
FailoverSinkProcessor maintains a prioritized list of sinks, guarranteeing that so long as one is available events will be processed.
FailoverSinkProcessor() - Constructor for class org.apache.flume.sink.FailoverSinkProcessor
 
failures - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
fastDateFormat - Variable in class org.apache.flume.sink.elasticsearch.AbstractElasticSearchIndexRequestBuilderFactory
fetchAndDeleteEvent(String, Connection) - Method in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
fetchAndDeleteEvent(String, Connection) - Method in class org.apache.flume.channel.jdbc.impl.MySQLSchemaHandler
 
fetchAndDeleteEvent(String, Connection) - Method in interface org.apache.flume.channel.jdbc.impl.SchemaHandler
Retrieves the next persistent event from the database.
fieldForId(int) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
fieldForId(int) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
 
fieldForId(int) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
 
fieldForId(int) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
 
fieldForId(int) - Method in class org.apache.flume.source.scribe.LogEntry
 
fieldForId(int) - Method in class org.apache.flume.source.scribe.Scribe.Log_args
 
fieldForId(int) - Method in class org.apache.flume.source.scribe.Scribe.Log_result
 
fieldForId(int) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
fieldForId(int) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
 
fieldForId(int) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
 
fieldForId(int) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
fieldForId(int) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
 
fields - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
FILE_LOCK - Static variable in class org.apache.flume.channel.file.Log
 
FileChannel - Class in org.apache.flume.channel.file
A durable Channel implementation that uses the local file system for its storage.
FileChannel() - Constructor for class org.apache.flume.channel.file.FileChannel
 
FileChannelConfiguration - Class in org.apache.flume.channel.file
 
FileChannelConfiguration() - Constructor for class org.apache.flume.channel.file.FileChannelConfiguration
 
FileChannelIntegrityTool - Class in org.apache.flume.tools
 
FileChannelIntegrityTool() - Constructor for class org.apache.flume.tools.FileChannelIntegrityTool
 
FILEID_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
FILENAME_HEADER - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
Whether to include absolute path filename in a header.
FILENAME_HEADER_KEY - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
Header in which to put absolute path filename.
fileNameHeader(String) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
 
findByName(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.flume.source.scribe.LogEntry._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.flume.source.scribe.Scribe.Log_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.flume.source.scribe.Scribe.Log_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.flume.thrift.ThriftFlumeEvent._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByThriftId(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.flume.source.scribe.LogEntry._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.flume.source.scribe.Scribe.Log_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.flume.source.scribe.Scribe.Log_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.flume.thrift.ThriftFlumeEvent._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftIdOrThrow(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.flume.source.scribe.LogEntry._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.flume.source.scribe.Scribe.Log_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.flume.source.scribe.Scribe.Log_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.flume.thrift.ThriftFlumeEvent._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByValue(int) - Static method in enum com.cloudera.flume.handlers.thrift.EventStatus
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum com.cloudera.flume.handlers.thrift.Priority
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.flume.source.scribe.ResultCode
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.flume.thrift.Status
Find a the enum type by its integer value, as defined in the Thrift IDL.
firstSeen - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
FLOOR_MINIMUM_REQUIRED_SPACE - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
Minimum space floor is 1MB
FlumeConfiguration - Class in org.apache.flume.conf
FlumeConfiguration is an in memory representation of the hierarchical configuration namespace required by the ConfigurationProvider.
FlumeConfiguration(Properties) - Constructor for class org.apache.flume.conf.FlumeConfiguration
Deprecated.
please use the other constructor
FlumeConfiguration(Map<String, String>) - Constructor for class org.apache.flume.conf.FlumeConfiguration
Creates a populated Flume Configuration object.
FlumeConfiguration.AgentConfiguration - Class in org.apache.flume.conf
 
FlumeConfiguration.ComponentNameAndConfigKey - Class in org.apache.flume.conf
 
FlumeConfigurationError - Class in org.apache.flume.conf
 
FlumeConfigurationError(String, String, FlumeConfigurationErrorType, FlumeConfigurationError.ErrorOrWarning) - Constructor for class org.apache.flume.conf.FlumeConfigurationError
Component which had an error, specific key in error(which can be null)
FlumeConfigurationError.ErrorOrWarning - Enum in org.apache.flume.conf
 
FlumeConfigurationErrorType - Enum in org.apache.flume.conf
 
FlumeEventAvroEventSerializer - Class in org.apache.flume.serialization
 
FlumeEventAvroEventSerializer.Builder - Class in org.apache.flume.serialization
 
FlumeEventAvroEventSerializer.Builder() - Constructor for class org.apache.flume.serialization.FlumeEventAvroEventSerializer.Builder
 
FlumeException - Exception in org.apache.flume
Base class of all flume exceptions.
FlumeException(String) - Constructor for exception org.apache.flume.FlumeException
 
FlumeException(String, Throwable) - Constructor for exception org.apache.flume.FlumeException
 
FlumeException(Throwable) - Constructor for exception org.apache.flume.FlumeException
 
FlumeTool - Interface in org.apache.flume.tools
 
FlumeToolsMain - Class in org.apache.flume.tools
 
FlumeToolType - Enum in org.apache.flume.tools
 
flush() - Method in class org.apache.flume.serialization.AbstractAvroEventSerializer
 
flush() - Method in class org.apache.flume.serialization.BodyTextEventSerializer
 
flush() - Method in interface org.apache.flume.serialization.EventSerializer
Hook to flush any internal write buffers to the underlying stream.
flush() - Method in class org.apache.flume.serialization.HeaderAndBodyTextEventSerializer
 
flush() - Method in class org.apache.flume.sink.hdfs.AvroEventSerializer
 
format(Event) - Method in interface org.apache.flume.formatter.output.EventFormatter
Deprecated.
 
format(Event) - Method in class org.apache.flume.formatter.output.TextDelimitedOutputFormatter
Deprecated.
 
forSource(Source) - Static method in class org.apache.flume.SourceRunner
Static factory method to instantiate a source runner implementation that corresponds to the type of Source specified.
front() - Method in class org.apache.flume.channel.SpillableMemoryChannel.DrainOrderQueue
 
FSYNC_INTERVAL - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
 
FSYNC_PER_TXN - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
 

G

GANGLIA_DOUBLE_TYPE - Static variable in class org.apache.flume.instrumentation.GangliaServer
 
GangliaServer - Class in org.apache.flume.instrumentation
A Ganglia server that polls JMX based at a configured frequency (defaults to once every 60 seconds).
GangliaServer() - Constructor for class org.apache.flume.instrumentation.GangliaServer
 
GangliaServer.GangliaCollector - Class in org.apache.flume.instrumentation
Worker which polls JMX for all mbeans with ObjectName within the flume namespace: org.apache.flume.
GangliaServer.GangliaCollector() - Constructor for class org.apache.flume.instrumentation.GangliaServer.GangliaCollector
 
generateUUID() - Method in class org.apache.flume.sink.solr.morphline.UUIDInterceptor
 
get(String) - Method in class org.apache.flume.CounterGroup
 
get(String) - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
Retrieves the current value for this key
get() - Method in class org.apache.flume.sink.elasticsearch.client.RoundRobinList
 
getActions() - Method in interface org.apache.flume.sink.hbase.AsyncHbaseEventSerializer
Get the actions that should be written out to hbase as a result of this event.
getActions() - Method in interface org.apache.flume.sink.hbase.HbaseEventSerializer
Get the actions that should be written out to hbase as a result of this event.
getActions() - Method in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
 
getActions() - Method in class org.apache.flume.sink.hbase.SimpleAsyncHbaseEventSerializer
 
getActions() - Method in class org.apache.flume.sink.hbase.SimpleHbaseEventSerializer
 
getActiveLogs(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
repeated .ActiveLog activeLogs = 5;
getActiveLogs(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
repeated .ActiveLog activeLogs = 5;
getActiveLogs(int) - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
repeated .ActiveLog activeLogs = 5;
getActiveLogsBuilder(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
repeated .ActiveLog activeLogs = 5;
getActiveLogsBuilderList() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
repeated .ActiveLog activeLogs = 5;
getActiveLogsCount() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
repeated .ActiveLog activeLogs = 5;
getActiveLogsCount() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
repeated .ActiveLog activeLogs = 5;
getActiveLogsCount() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
repeated .ActiveLog activeLogs = 5;
getActiveLogsList() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
repeated .ActiveLog activeLogs = 5;
getActiveLogsList() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
repeated .ActiveLog activeLogs = 5;
getActiveLogsList() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
repeated .ActiveLog activeLogs = 5;
getActiveLogsOrBuilder(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
repeated .ActiveLog activeLogs = 5;
getActiveLogsOrBuilder(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
repeated .ActiveLog activeLogs = 5;
getActiveLogsOrBuilder(int) - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
repeated .ActiveLog activeLogs = 5;
getActiveLogsOrBuilderList() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
repeated .ActiveLog activeLogs = 5;
getActiveLogsOrBuilderList() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
repeated .ActiveLog activeLogs = 5;
getActiveLogsOrBuilderList() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
repeated .ActiveLog activeLogs = 5;
getAgentName() - Method in class org.apache.flume.node.AbstractConfigurationProvider
 
getAllChannels() - Method in class org.apache.flume.channel.AbstractChannelSelector
 
getAllChannels() - Method in interface org.apache.flume.ChannelSelector
 
getAllMBeans() - Static method in class org.apache.flume.instrumentation.util.JMXPollUtil
 
getAppendAcceptedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
 
getAppendAcceptedCount() - Method in interface org.apache.flume.instrumentation.SourceCounterMBean
 
getAppendBatchAcceptedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
 
getAppendBatchAcceptedCount() - Method in interface org.apache.flume.instrumentation.SourceCounterMBean
 
getAppendBatchReceivedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
 
getAppendBatchReceivedCount() - Method in interface org.apache.flume.instrumentation.SourceCounterMBean
 
getAppendReceivedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
 
getAppendReceivedCount() - Method in interface org.apache.flume.instrumentation.SourceCounterMBean
 
getAsyncClient(TNonblockingTransport) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.flume.source.scribe.Scribe.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.AsyncClient.Factory
 
getBackupCheckpointPosition() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
optional sfixed64 backupCheckpointPosition = 6;
getBackupCheckpointPosition() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
optional sfixed64 backupCheckpointPosition = 6;
getBackupCheckpointPosition() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
optional sfixed64 backupCheckpointPosition = 6;
getBackupCheckpointWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
optional sfixed64 backupCheckpointWriteOrderID = 7;
getBackupCheckpointWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
optional sfixed64 backupCheckpointWriteOrderID = 7;
getBackupCheckpointWriteOrderID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
optional sfixed64 backupCheckpointWriteOrderID = 7;
getBase() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.SpillableString
 
getBaseDirectory() - Method in class org.apache.flume.formatter.output.PathManager
 
getBasePayload() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
getBatchCompleteCount() - Method in class org.apache.flume.instrumentation.SinkCounter
 
getBatchCompleteCount() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
 
getBatchEmptyCount() - Method in class org.apache.flume.instrumentation.SinkCounter
 
getBatchEmptyCount() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
 
getBatchSize() - Method in class org.apache.flume.api.AbstractRpcClient
 
getBatchSize() - Method in interface org.apache.flume.api.RpcClient
Returns the maximum number of events that may be batched at once by appendBatch().
getBatchSize() - Method in class org.apache.flume.api.ThriftRpcClient
 
getBatchUnderflowCount() - Method in class org.apache.flume.instrumentation.SinkCounter
 
getBatchUnderflowCount() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
 
getBody() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
getBody() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
required bytes body = 2;
getBody() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
required bytes body = 2;
getBody() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventOrBuilder
required bytes body = 2;
getBody() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
getBody() - Method in interface org.apache.flume.Event
Returns the raw byte array of the data contained in this event.
getBody() - Method in class org.apache.flume.event.JSONEvent
 
getBody() - Method in class org.apache.flume.event.SimpleEvent
 
getBody() - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
getBoolean(String, Boolean) - Method in class org.apache.flume.Context
Gets value mapped to key, returning defaultValue if unmapped.
getBoolean(String) - Method in class org.apache.flume.Context
Gets value mapped to key, returning null if unmapped.
getBranch() - Static method in class org.apache.flume.tools.VersionInfo
Get the branch on which this originated.
getBuilderClass() - Method in enum org.apache.flume.channel.file.encryption.KeyProviderType
 
getBuilderClass() - Method in enum org.apache.flume.interceptor.InterceptorType
 
getBuilderClass() - Method in enum org.apache.flume.serialization.EventDeserializerType
 
getBuilderClass() - Method in enum org.apache.flume.serialization.EventSerializerType
 
getBuilderClass() - Method in enum org.apache.flume.sink.hdfs.SequenceFileSerializerType
 
getBuildVersion() - Static method in class org.apache.flume.tools.VersionInfo
Returns the build version info which includes version, revision, user, date and source checksum
getByName(String) - Static method in enum org.apache.flume.channel.jdbc.DatabaseType
 
getByName(String) - Static method in enum org.apache.flume.channel.jdbc.TransactionIsolation
 
getByName(String) - Static method in enum org.apache.flume.clients.log4jappender.Log4jAvroHeaders
 
getCategory() - Method in class org.apache.flume.source.scribe.LogEntry
 
getChannel() - Method in class org.apache.flume.conf.sink.SinkConfiguration
 
getChannel(String) - Method in class org.apache.flume.conf.sink.SinkConfiguration
 
getChannel() - Method in class org.apache.flume.sink.AbstractSink
 
getChannel() - Method in interface org.apache.flume.Sink
 
getChannelCapacity() - Method in class org.apache.flume.instrumentation.ChannelCounter
 
getChannelCapacity() - Method in interface org.apache.flume.instrumentation.ChannelCounterMBean
 
getChannelClassName() - Method in enum org.apache.flume.conf.channel.ChannelType
 
getChannelConfigMap() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
 
getChannelConfigurationType() - Method in enum org.apache.flume.conf.channel.ChannelConfiguration.ChannelConfigurationType
 
getChannelContext() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
 
getChannelFillPercentage() - Method in class org.apache.flume.instrumentation.ChannelCounter
 
getChannelFillPercentage() - Method in interface org.apache.flume.instrumentation.ChannelCounterMBean
 
getChannelListFromNames(String, Map<String, Channel>) - Method in class org.apache.flume.channel.AbstractChannelSelector
Given a list of channel names as space delimited string, returns list of channels.
getChannelName() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
getChannelNameMap() - Method in class org.apache.flume.channel.AbstractChannelSelector
 
getChannelProcessor() - Method in class org.apache.flume.source.AbstractSource
 
getChannelProcessor() - Method in class org.apache.flume.source.BasicSourceSemantics
 
getChannelProcessor() - Method in interface org.apache.flume.Source
Returns the channel processor that will handle this source's events.
getChannels() - Method in class org.apache.flume.conf.channel.ChannelSelectorConfiguration
 
getChannels() - Method in class org.apache.flume.conf.source.SourceConfiguration
 
getChannels() - Method in interface org.apache.flume.node.MaterializedConfiguration
 
getChannels() - Method in class org.apache.flume.node.SimpleMaterializedConfiguration
 
getChannelSelectorClassName() - Method in enum org.apache.flume.conf.channel.ChannelSelectorType
 
getChannelSelectorConfigurationType() - Method in enum org.apache.flume.conf.channel.ChannelSelectorConfiguration.ChannelSelectorConfigurationType
 
getChannelSet() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
 
getChannelSize(Connection) - Method in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
getChannelSize(Connection) - Method in class org.apache.flume.channel.jdbc.impl.MySQLSchemaHandler
 
getChannelSize(Connection) - Method in interface org.apache.flume.channel.jdbc.impl.SchemaHandler
Returns the current size of the channel using the connection specified that must have an active transaction ongoing.
getChannelSize() - Method in class org.apache.flume.instrumentation.ChannelCounter
 
getChannelSize() - Method in interface org.apache.flume.instrumentation.ChannelCounterMBean
 
getCheckpointPosition() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
required sfixed64 checkpointPosition = 3;
getCheckpointPosition() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
required sfixed64 checkpointPosition = 3;
getCheckpointPosition() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
required sfixed64 checkpointPosition = 3;
getCheckpointWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
required sfixed64 checkpointWriteOrderID = 4;
getCheckpointWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
required sfixed64 checkpointWriteOrderID = 4;
getCheckpointWriteOrderID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
required sfixed64 checkpointWriteOrderID = 4;
getChecksum() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
optional sfixed64 checksum = 2;
getChecksum() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
optional sfixed64 checksum = 2;
getChecksum() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.PutOrBuilder
optional sfixed64 checksum = 2;
getCipherProvider() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
required string cipherProvider = 1;
getCipherProvider() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
required string cipherProvider = 1;
getCipherProvider() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryptionOrBuilder
required string cipherProvider = 1;
getCipherProviderBytes() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
required string cipherProvider = 1;
getCipherProviderBytes() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
required string cipherProvider = 1;
getCipherProviderBytes() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryptionOrBuilder
required string cipherProvider = 1;
getClass(String) - Method in class org.apache.flume.channel.DefaultChannelFactory
 
getClass(String) - Method in interface org.apache.flume.ChannelFactory
 
getClass(String) - Method in class org.apache.flume.sink.DefaultSinkFactory
 
getClass(String) - Method in interface org.apache.flume.SinkFactory
 
getClass(String) - Method in class org.apache.flume.source.DefaultSourceFactory
 
getClass(String) - Method in interface org.apache.flume.SourceFactory
 
getClassInstance() - Method in enum org.apache.flume.tools.FlumeToolType
 
getClient(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client.Factory
 
getClient(String, String[], String, ElasticSearchEventSerializer, ElasticSearchIndexRequestBuilderFactory) - Method in class org.apache.flume.sink.elasticsearch.client.ElasticSearchClientFactory
 
getClient(TProtocol) - Method in class org.apache.flume.source.scribe.Scribe.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.flume.source.scribe.Scribe.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.Client.Factory
 
getClientClassName() - Method in enum org.apache.flume.api.RpcClientFactory.ClientType
 
getClock() - Static method in class org.apache.flume.formatter.output.BucketPath
 
getCode() - Method in enum org.apache.flume.channel.jdbc.TransactionIsolation
 
getCodec() - Method in class org.apache.flume.channel.file.encryption.CipherProvider.Decryptor
 
getCodec() - Method in class org.apache.flume.channel.file.encryption.CipherProvider.Encryptor
 
getCommittedCount() - Method in class org.apache.flume.channel.file.Log
 
getComponentName() - Method in class org.apache.flume.conf.ComponentConfiguration
 
getComponentName() - Method in class org.apache.flume.conf.FlumeConfiguration.ComponentNameAndConfigKey
 
getComponentName() - Method in class org.apache.flume.conf.FlumeConfigurationError
 
getComponentType() - Method in enum org.apache.flume.conf.ComponentConfiguration.ComponentType
 
getConfig() - Method in class org.apache.flume.sink.hbase.HBaseSink
 
getConfigKey() - Method in class org.apache.flume.conf.FlumeConfiguration.ComponentNameAndConfigKey
 
getConfiguration(String) - Method in enum org.apache.flume.conf.channel.ChannelConfiguration.ChannelConfigurationType
 
getConfiguration(String) - Method in enum org.apache.flume.conf.channel.ChannelSelectorConfiguration.ChannelSelectorConfigurationType
 
getConfiguration(String) - Method in enum org.apache.flume.conf.sink.SinkConfiguration.SinkConfigurationType
 
getConfiguration(String) - Method in enum org.apache.flume.conf.sink.SinkProcessorConfiguration.SinkProcessorConfigurationType
 
getConfiguration(String) - Method in enum org.apache.flume.conf.source.SourceConfiguration.SourceConfigurationType
 
getConfiguration() - Method in class org.apache.flume.node.AbstractConfigurationProvider
 
getConfiguration() - Method in interface org.apache.flume.node.ConfigurationProvider
 
getConfigurationErrors() - Method in class org.apache.flume.conf.FlumeConfiguration
 
getConfigurationFor(String) - Method in class org.apache.flume.conf.FlumeConfiguration
 
getConnection() - Method in class org.apache.flume.channel.jdbc.impl.JdbcTransactionImpl
 
getConnectionClosedCount() - Method in class org.apache.flume.instrumentation.SinkCounter
 
getConnectionClosedCount() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
 
getConnectionCreatedCount() - Method in class org.apache.flume.instrumentation.SinkCounter
 
getConnectionCreatedCount() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
 
getConnectionFailedCount() - Method in class org.apache.flume.instrumentation.SinkCounter
 
getConnectionFailedCount() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
 
getContentBuilder(Event) - Method in class org.apache.flume.sink.elasticsearch.ElasticSearchDynamicSerializer
 
getContentBuilder(Event) - Method in interface org.apache.flume.sink.elasticsearch.ElasticSearchEventSerializer
Return an BytesStream made up of the serialized flume event
getContentBuilder(Event) - Method in class org.apache.flume.sink.elasticsearch.ElasticSearchLogStashEventSerializer
 
getCount() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
required sfixed32 count = 2;
getCount() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
required sfixed32 count = 2;
getCount() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.ActiveLogOrBuilder
required sfixed32 count = 2;
getCounter(String) - Method in class org.apache.flume.CounterGroup
 
getCounters() - Method in class org.apache.flume.CounterGroup
 
getCurrentFile() - Method in class org.apache.flume.formatter.output.PathManager
 
getDate() - Static method in class org.apache.flume.tools.VersionInfo
The date that Flume was compiled.
getDecrypter(String, Key, byte[]) - Static method in class org.apache.flume.channel.file.encryption.CipherProviderFactory
 
getDefaultInstance(String, Integer) - Static method in class org.apache.flume.api.RpcClientFactory
Returns an instance of RpcClient connected to the specified hostname and port.
getDefaultInstance(String, Integer, Integer) - Static method in class org.apache.flume.api.RpcClientFactory
Returns an instance of RpcClient connected to the specified hostname and port with the specified batchSize.
getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
getDefaultInstance() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback.Builder
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter.Builder
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
 
getDefaultInstanceForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
getDepth() - Method in class org.apache.flume.channel.file.FileChannel
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback.Builder
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter.Builder
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
 
getDescriptor() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
 
getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
 
getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
 
getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
 
getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
 
getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
 
getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
 
getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
 
getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback.Builder
 
getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
 
getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter.Builder
 
getDescriptorForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
 
getDfs(Configuration, Path) - Method in class org.apache.flume.sink.hdfs.HDFSDataStream
 
getDirectMemorySize() - Static method in class org.apache.flume.tools.DirectMemoryUtils
 
getDirectory() - Method in class org.apache.flume.sink.RollingFileSink
 
getEncrypter(String, Key) - Static method in class org.apache.flume.channel.file.encryption.CipherProviderFactory
 
getEncryption() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
optional .LogFileEncryption encryption = 5;
getEncryption() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
optional .LogFileEncryption encryption = 5;
getEncryption() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
optional .LogFileEncryption encryption = 5;
getEncryptionBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
optional .LogFileEncryption encryption = 5;
getEncryptionOrBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
optional .LogFileEncryption encryption = 5;
getEncryptionOrBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
optional .LogFileEncryption encryption = 5;
getEncryptionOrBuilder() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
optional .LogFileEncryption encryption = 5;
getError() - Method in enum org.apache.flume.conf.FlumeConfigurationErrorType
 
getErrorOrWarning() - Method in class org.apache.flume.conf.FlumeConfigurationError
 
getErrors() - Method in class org.apache.flume.conf.ComponentConfiguration
 
getErrorType() - Method in class org.apache.flume.conf.FlumeConfigurationError
 
getEscapeMapping(String, Map<String, String>) - Static method in class org.apache.flume.formatter.output.BucketPath
Deprecated.
getEscapeMapping(String, Map<String, String>, boolean, int, int) - Static method in class org.apache.flume.formatter.output.BucketPath
Deprecated.
getEvent() - Method in class org.apache.flume.channel.file.LogRecord
 
getEvent() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
required .FlumeEvent event = 1;
getEvent() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
required .FlumeEvent event = 1;
getEvent() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.PutOrBuilder
required .FlumeEvent event = 1;
getEvent() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
 
getEventAcceptedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
 
getEventAcceptedCount() - Method in interface org.apache.flume.instrumentation.SourceCounterMBean
 
getEventBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
required .FlumeEvent event = 1;
getEventDrainAttemptCount() - Method in class org.apache.flume.instrumentation.SinkCounter
 
getEventDrainAttemptCount() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
 
getEventDrainSuccessCount() - Method in class org.apache.flume.instrumentation.SinkCounter
 
getEventDrainSuccessCount() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
 
getEventId() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
getEventOrBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
required .FlumeEvent event = 1;
getEventOrBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
required .FlumeEvent event = 1;
getEventOrBuilder() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.PutOrBuilder
required .FlumeEvent event = 1;
getEventPutAttemptCount() - Method in class org.apache.flume.instrumentation.ChannelCounter
 
getEventPutAttemptCount() - Method in interface org.apache.flume.instrumentation.ChannelCounterMBean
 
getEventPutSuccessCount() - Method in class org.apache.flume.instrumentation.ChannelCounter
 
getEventPutSuccessCount() - Method in interface org.apache.flume.instrumentation.ChannelCounterMBean
 
getEventReceivedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
 
getEventReceivedCount() - Method in interface org.apache.flume.instrumentation.SourceCounterMBean
 
getEvents(HttpServletRequest) - Method in class org.apache.flume.sink.solr.morphline.BlobHandler
 
getEvents(HttpServletRequest) - Method in interface org.apache.flume.source.http.HTTPSourceHandler
Takes an HttpServletRequest and returns a list of Flume Events.
getEvents(HttpServletRequest) - Method in class org.apache.flume.source.http.JSONHandler
Takes an HttpServletRequest and returns a list of Flume Events.
getEvents() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
getEventsIterator() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
getEventSize() - Method in class org.apache.flume.source.SyslogUtils
 
getEventsSize() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
getEventTakeAttemptCount() - Method in class org.apache.flume.instrumentation.ChannelCounter
 
getEventTakeAttemptCount() - Method in interface org.apache.flume.instrumentation.ChannelCounterMBean
 
getEventTakeSuccessCount() - Method in class org.apache.flume.instrumentation.ChannelCounter
 
getEventTakeSuccessCount() - Method in interface org.apache.flume.instrumentation.ChannelCounterMBean
 
getEvt() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
 
getFieldName() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
 
getFieldName() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
 
getFieldName() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
 
getFieldName() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
 
getFieldName() - Method in enum org.apache.flume.source.scribe.LogEntry._Fields
 
getFieldName() - Method in enum org.apache.flume.source.scribe.Scribe.Log_args._Fields
 
getFieldName() - Method in enum org.apache.flume.source.scribe.Scribe.Log_result._Fields
 
getFieldName() - Method in enum org.apache.flume.thrift.ThriftFlumeEvent._Fields
 
getFieldName() - Method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_args._Fields
 
getFieldName() - Method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_result._Fields
 
getFieldName() - Method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args._Fields
 
getFieldName() - Method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result._Fields
 
getFields() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
getFieldsSize() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
getFieldValue(ThriftFlumeEvent._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
getFieldValue(ThriftFlumeEventServer.append_args._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
 
getFieldValue(ThriftFlumeEventServer.close_args._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
 
getFieldValue(ThriftFlumeEventServer.close_result._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
 
getFieldValue(LogEntry._Fields) - Method in class org.apache.flume.source.scribe.LogEntry
 
getFieldValue(Scribe.Log_args._Fields) - Method in class org.apache.flume.source.scribe.Scribe.Log_args
 
getFieldValue(Scribe.Log_result._Fields) - Method in class org.apache.flume.source.scribe.Scribe.Log_result
 
getFieldValue(ThriftFlumeEvent._Fields) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
getFieldValue(ThriftSourceProtocol.append_args._Fields) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
 
getFieldValue(ThriftSourceProtocol.append_result._Fields) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
 
getFieldValue(ThriftSourceProtocol.appendBatch_args._Fields) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
getFieldValue(ThriftSourceProtocol.appendBatch_result._Fields) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
 
getFileHandle() - Method in class org.apache.flume.channel.file.LogFile.SequentialReader
 
getFileID() - Method in class org.apache.flume.channel.file.LogRecord
 
getFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
required sfixed32 fileID = 1;
getFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
required sfixed32 fileID = 1;
getFileID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.TakeOrBuilder
required sfixed32 fileID = 1;
getFileIndex() - Method in class org.apache.flume.formatter.output.PathManager
 
getFlumeConfiguration() - Method in class org.apache.flume.node.AbstractConfigurationProvider
 
getFlumeConfiguration() - Method in class org.apache.flume.node.PropertiesFileConfigurationProvider
 
getFsDesiredReplication() - Method in class org.apache.flume.sink.hdfs.AbstractHDFSWriter
 
getHandler(DatabaseType, DataSource) - Static method in class org.apache.flume.channel.jdbc.impl.SchemaHandlerFactory
 
getHeaderEntries() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
getHeaders(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
repeated .FlumeEventHeader headers = 1;
getHeaders(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
repeated .FlumeEventHeader headers = 1;
getHeaders(int) - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventOrBuilder
repeated .FlumeEventHeader headers = 1;
getHeaders() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
getHeaders() - Method in interface org.apache.flume.Event
Returns a map of name-value pairs describing the data stored in the body.
getHeaders() - Method in class org.apache.flume.event.JSONEvent
 
getHeaders() - Method in class org.apache.flume.event.SimpleEvent
 
getHeaders() - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
getHeadersBuilder(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
repeated .FlumeEventHeader headers = 1;
getHeadersBuilderList() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
repeated .FlumeEventHeader headers = 1;
getHeadersCount() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
repeated .FlumeEventHeader headers = 1;
getHeadersCount() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
repeated .FlumeEventHeader headers = 1;
getHeadersCount() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventOrBuilder
repeated .FlumeEventHeader headers = 1;
getHeadersList() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
repeated .FlumeEventHeader headers = 1;
getHeadersList() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
repeated .FlumeEventHeader headers = 1;
getHeadersList() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventOrBuilder
repeated .FlumeEventHeader headers = 1;
getHeadersOrBuilder(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
repeated .FlumeEventHeader headers = 1;
getHeadersOrBuilder(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
repeated .FlumeEventHeader headers = 1;
getHeadersOrBuilder(int) - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventOrBuilder
repeated .FlumeEventHeader headers = 1;
getHeadersOrBuilderList() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
repeated .FlumeEventHeader headers = 1;
getHeadersOrBuilderList() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
repeated .FlumeEventHeader headers = 1;
getHeadersOrBuilderList() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventOrBuilder
repeated .FlumeEventHeader headers = 1;
getHeadersSize() - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
getHost() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
getHostInfoList(Properties) - Static method in class org.apache.flume.api.HostInfo
 
getHostName() - Method in class org.apache.flume.api.HostInfo
 
getId() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
 
getIncrements() - Method in interface org.apache.flume.sink.hbase.AsyncHbaseEventSerializer
Get the increments that should be made in hbase as a result of this event.
getIncrements() - Method in interface org.apache.flume.sink.hbase.HbaseEventSerializer
 
getIncrements() - Method in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
 
getIncrements() - Method in class org.apache.flume.sink.hbase.SimpleAsyncHbaseEventSerializer
 
getIncrements() - Method in class org.apache.flume.sink.hbase.SimpleHbaseEventSerializer
 
getIndexList() - Method in class org.apache.flume.util.OrderSelector
 
getIndexName(String, long) - Method in class org.apache.flume.sink.elasticsearch.AbstractElasticSearchIndexRequestBuilderFactory
Gets the name of the index to use for an index request
getIndexName(Event) - Method in interface org.apache.flume.sink.elasticsearch.IndexNameBuilder
Gets the name of the index to use for an index request
getIndexName(Event) - Method in class org.apache.flume.sink.elasticsearch.SimpleIndexNameBuilder
 
getIndexName(Event) - Method in class org.apache.flume.sink.elasticsearch.TimeBasedIndexNameBuilder
Gets the name of the index to use for an index request
getIndexPrefix(Event) - Method in interface org.apache.flume.sink.elasticsearch.IndexNameBuilder
Gets the prefix of index to use for an index request.
getIndexPrefix(Event) - Method in class org.apache.flume.sink.elasticsearch.SimpleIndexNameBuilder
 
getIndexPrefix(Event) - Method in class org.apache.flume.sink.elasticsearch.TimeBasedIndexNameBuilder
 
getInstance(Properties) - Static method in class org.apache.flume.api.RpcClientFactory
Returns an instance of RpcClient, optionally with failover.
getInstance(File) - Static method in class org.apache.flume.api.RpcClientFactory
Delegates to RpcClientFactory.getInstance(Properties props), given a File path to a Properties file.
getInstance(String, Integer) - Static method in class org.apache.flume.api.RpcClientFactory
Deprecated. 
getInstance(String, Integer, Integer) - Static method in class org.apache.flume.api.RpcClientFactory
Deprecated. 
getInstance(String, Context) - Static method in class org.apache.flume.channel.file.encryption.KeyProviderFactory
 
getInstance(File, String) - Static method in class org.apache.flume.serialization.DurablePositionTracker
If the file exists at startup, then read it, roll it, and open a new one.
getInstance(String, Context, ResettableInputStream) - Static method in class org.apache.flume.serialization.EventDeserializerFactory
 
getInstance(String, Context, OutputStream) - Static method in class org.apache.flume.serialization.EventSerializerFactory
 
getInteger(String, Integer) - Method in class org.apache.flume.Context
Gets value mapped to key, returning defaultValue if unmapped.
getInteger(String) - Method in class org.apache.flume.Context
Gets value mapped to key, returning null if unmapped.
GetJavaProperty - Class in org.apache.flume.tools
A generic way for querying Java properties.
GetJavaProperty() - Constructor for class org.apache.flume.tools.GetJavaProperty
 
getKey(String) - Method in class org.apache.flume.channel.file.encryption.JCEFileKeyProvider
 
getKey(String) - Method in class org.apache.flume.channel.file.encryption.KeyProvider
Returns a non-null Key
getKey() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
required string key = 1;
getKey() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
required string key = 1;
getKey() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeaderOrBuilder
required string key = 1;
getKey() - Method in class org.apache.flume.conf.FlumeConfigurationError
 
getKey() - Method in class org.apache.flume.sink.hdfs.SequenceFileSerializer.Record
 
getKeyAlias() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
required string keyAlias = 2;
getKeyAlias() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
required string keyAlias = 2;
getKeyAlias() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryptionOrBuilder
required string keyAlias = 2;
getKeyAliasBytes() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
required string keyAlias = 2;
getKeyAliasBytes() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
required string keyAlias = 2;
getKeyAliasBytes() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryptionOrBuilder
required string keyAlias = 2;
getKeyBytes() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
required string key = 1;
getKeyBytes() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
required string key = 1;
getKeyBytes() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeaderOrBuilder
required string key = 1;
getKeyClass() - Method in class org.apache.flume.sink.hdfs.HDFSTextSerializer
 
getKeyClass() - Method in class org.apache.flume.sink.hdfs.HDFSWritableSerializer
 
getKeyClass() - Method in interface org.apache.flume.sink.hdfs.SequenceFileSerializer
 
getKeyProvider() - Method in class org.apache.flume.channel.file.LogFile.SequentialReader
 
getKeyTab() - Method in class org.apache.flume.sink.hdfs.KerberosUser
 
getLastConnectedServerAddress() - Method in class org.apache.flume.api.FailoverRpcClient
Get the last socket address this client connected to.
getLastFileRead() - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader
Return the filename which generated the data from the last successful ReliableSpoolingFileEventReader.readEvents(int) call.
getLifecycleState() - Method in class org.apache.flume.channel.AbstractChannel
 
getLifecycleState() - Method in interface org.apache.flume.lifecycle.LifecycleAware
Return the current state of the service or component.
getLifecycleState() - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
 
getLifecycleState() - Method in class org.apache.flume.node.PollingPropertiesFileConfigurationProvider
 
getLifecycleState() - Method in class org.apache.flume.sink.AbstractSink
 
getLifecycleState() - Method in class org.apache.flume.sink.AbstractSinkProcessor
 
getLifecycleState() - Method in class org.apache.flume.sink.AbstractSinkSelector
 
getLifecycleState() - Method in class org.apache.flume.sink.DefaultSinkProcessor
 
getLifecycleState() - Method in class org.apache.flume.SinkRunner
 
getLifecycleState() - Method in class org.apache.flume.source.AbstractSource
 
getLifecycleState() - Method in class org.apache.flume.source.BasicSourceSemantics
 
getLifecycleState() - Method in class org.apache.flume.source.EventDrivenSourceRunner
 
getLifecycleState() - Method in class org.apache.flume.source.PollableSourceRunner
 
getLocalClient(String, ElasticSearchEventSerializer, ElasticSearchIndexRequestBuilderFactory) - Method in class org.apache.flume.sink.elasticsearch.client.ElasticSearchClientFactory
Used for tests only.
getLogFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
required sfixed32 logFileID = 1;
getLogFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
required sfixed32 logFileID = 1;
getLogFileID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.ActiveLogOrBuilder
required sfixed32 logFileID = 1;
getLogFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
required sfixed32 logFileID = 2;
getLogFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
required sfixed32 logFileID = 2;
getLogFileID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
required sfixed32 logFileID = 2;
getLong(String, Long) - Method in class org.apache.flume.Context
Gets value mapped to key, returning defaultValue if unmapped.
getLong(String) - Method in class org.apache.flume.Context
Gets value mapped to key, returning null if unmapped.
getMarkPosition() - Method in interface org.apache.flume.serialization.RemoteMarkable
Return the saved mark position without moving the mark pointer.
getMarkPosition() - Method in class org.apache.flume.serialization.ResettableFileInputStream
 
getMaxMemQueueSize() - Method in class org.apache.flume.channel.SpillableMemoryChannel
 
getMaxTimeOut() - Method in class org.apache.flume.util.OrderSelector
 
getMaxTries() - Method in class org.apache.flume.api.FailoverRpcClient
Get the maximum number of "failed" hosts the client will try to establish connection to before throwing an exception.
getMemoryCapacity() - Method in class org.apache.flume.channel.SpillableMemoryChannel
 
getMessage() - Method in class org.apache.flume.source.scribe.LogEntry
 
getMessages() - Method in class org.apache.flume.source.scribe.Scribe.Log_args
 
getMessagesIterator() - Method in class org.apache.flume.source.scribe.Scribe.Log_args
 
getMessagesSize() - Method in class org.apache.flume.source.scribe.Scribe.Log_args
 
getMonitorClass() - Method in enum org.apache.flume.instrumentation.MonitoringType
 
getName() - Method in class org.apache.flume.channel.AbstractChannel
 
getName() - Method in class org.apache.flume.channel.AbstractChannelSelector
 
getName() - Method in enum org.apache.flume.channel.jdbc.DatabaseType
 
getName() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
 
getName() - Method in enum org.apache.flume.channel.jdbc.TransactionIsolation
 
getName() - Method in enum org.apache.flume.clients.log4jappender.Log4jAvroHeaders
 
getName() - Method in class org.apache.flume.CounterGroup
 
getName() - Method in interface org.apache.flume.NamedComponent
 
getName() - Method in class org.apache.flume.sink.AbstractSink
 
getName() - Method in class org.apache.flume.source.AbstractSource
 
getName() - Method in class org.apache.flume.source.BasicSourceSemantics
 
getNames() - Static method in enum org.apache.flume.tools.FlumeToolType
 
getNameString() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
 
getNanos() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
getNanoTimestampKey(String) - Static method in class org.apache.flume.sink.hbase.SimpleRowKeyGenerator
 
getNumCurrentReplicas() - Method in class org.apache.flume.sink.hdfs.AbstractHDFSWriter
This method gets the datanode replication count for the current open file.
getObjects() - Method in class org.apache.flume.util.OrderSelector
Get the list of objects to be ordered.
getOffset() - Method in class org.apache.flume.channel.file.LogRecord
 
getOffset() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
required sfixed32 offset = 2;
getOffset() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
required sfixed32 offset = 2;
getOffset() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.TakeOrBuilder
required sfixed32 offset = 2;
getOpenConnectionCount() - Method in class org.apache.flume.instrumentation.SourceCounter
 
getOpenConnectionCount() - Method in interface org.apache.flume.instrumentation.SourceCounterMBean
 
getOptionalChannels(Event) - Method in class org.apache.flume.channel.MultiplexingChannelSelector
 
getOptionalChannels(Event) - Method in class org.apache.flume.channel.ReplicatingChannelSelector
 
getOptionalChannels(Event) - Method in interface org.apache.flume.ChannelSelector
Returns a list of optional channels.
getOutputStream() - Method in class org.apache.flume.serialization.AbstractAvroEventSerializer
Returns the stream to serialize data into.
getOutputStream() - Method in class org.apache.flume.serialization.FlumeEventAvroEventSerializer
 
getOverflowCapacity() - Method in class org.apache.flume.channel.SpillableMemoryChannel
 
getOverflowTimeout() - Method in class org.apache.flume.channel.SpillableMemoryChannel
 
getParameters() - Method in class org.apache.flume.channel.file.encryption.CipherProvider.Encryptor
 
getParameters() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
optional bytes parameters = 3;
getParameters() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
optional bytes parameters = 3;
getParameters() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryptionOrBuilder
optional bytes parameters = 3;
getParameters() - Method in class org.apache.flume.Context
Gets a copy of the backing map structure.
getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
getParserForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
getPolicy() - Method in class org.apache.flume.SinkRunner
 
getPollFrequency() - Method in class org.apache.flume.instrumentation.GangliaServer
 
getPortNumber() - Method in class org.apache.flume.api.HostInfo
 
getPosition() - Method in class org.apache.flume.channel.file.LogFile.SequentialReader
 
getPosition() - Method in class org.apache.flume.serialization.DurablePositionTracker
 
getPosition() - Method in interface org.apache.flume.serialization.PositionTracker
 
getPostvalidationConfig() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
 
getPrefix() - Method in class org.apache.flume.sink.solr.morphline.UUIDInterceptor
 
getPrevalidationConfig() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
 
getPrincipal() - Method in class org.apache.flume.sink.hdfs.KerberosUser
 
getPriority() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
getProcessor() - Method in class org.apache.flume.sink.SinkGroup
 
getProcessor(Context, List<Sink>) - Static method in class org.apache.flume.sink.SinkProcessorFactory
Creates a sink processor and configures it using the provided context
getProcessor(ComponentConfiguration, List<Sink>) - Static method in class org.apache.flume.sink.SinkProcessorFactory
 
getProcessorContext() - Method in class org.apache.flume.conf.sink.SinkGroupConfiguration
 
getProvider(Context, String) - Static method in class org.apache.flume.channel.jdbc.JdbcChannelProviderFactory
 
getProviderClass() - Method in enum org.apache.flume.channel.file.encryption.CipherProviderType
 
getPutCount() - Method in class org.apache.flume.channel.file.Log
 
getQueueHead() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
required sfixed32 queueHead = 4;
getQueueHead() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
required sfixed32 queueHead = 4;
getQueueHead() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
required sfixed32 queueHead = 4;
getQueueSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
required sfixed32 queueSize = 3;
getQueueSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
required sfixed32 queueSize = 3;
getQueueSize() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
required sfixed32 queueSize = 3;
getRandomKey(String) - Static method in class org.apache.flume.sink.hbase.SimpleRowKeyGenerator
 
getReadCount() - Method in class org.apache.flume.channel.file.Log
 
getReferenceName() - Method in class org.apache.flume.api.HostInfo
 
getRequiredChannels(Event) - Method in class org.apache.flume.channel.MultiplexingChannelSelector
 
getRequiredChannels(Event) - Method in class org.apache.flume.channel.ReplicatingChannelSelector
 
getRequiredChannels(Event) - Method in interface org.apache.flume.ChannelSelector
Returns a list of required channels.
getResult() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.append_call
 
getResult() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.close_call
 
getResult() - Method in class org.apache.flume.source.scribe.Scribe.AsyncClient.Log_call
 
getResult() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.AsyncClient.append_call
 
getResult() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.AsyncClient.appendBatch_call
 
getRevision() - Static method in class org.apache.flume.tools.VersionInfo
Get the subversion revision number for the root directory
getRollbackCount() - Method in class org.apache.flume.channel.file.Log
 
getRollInterval() - Method in class org.apache.flume.sink.RollingFileSink
 
getRowKey(Calendar) - Method in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
Returns a row-key with the following format: [time in millis]-[random key]-[nonce]
getRowKey() - Method in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
 
getSchema() - Method in class org.apache.flume.serialization.AbstractAvroEventSerializer
Returns the parsed Avro schema corresponding to the data being written and the parameterized type specified.
getSchema() - Method in class org.apache.flume.serialization.FlumeEventAvroEventSerializer
 
getSelector() - Method in class org.apache.flume.channel.ChannelProcessor
 
getSelectorConfiguration() - Method in class org.apache.flume.conf.source.SourceConfiguration
 
getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
getSerializedSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
getSeriesTimestamp() - Method in class org.apache.flume.formatter.output.PathManager
 
getSinkClassName() - Method in enum org.apache.flume.conf.sink.SinkType
 
getSinkConfigMap() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
 
getSinkConfigurationType() - Method in enum org.apache.flume.conf.sink.SinkConfiguration.SinkConfigurationType
 
getSinkContext() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
 
getSinkGroupConfigMap() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
 
getSinkgroupSet() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
 
getSinkProcessorClassName() - Method in enum org.apache.flume.conf.sink.SinkProcessorType
 
getSinkProcessorConfiguration() - Method in class org.apache.flume.conf.sink.SinkGroupConfiguration
 
getSinkProcessorConfigurationType() - Method in enum org.apache.flume.conf.sink.SinkProcessorConfiguration.SinkProcessorConfigurationType
 
getSinkRunners() - Method in interface org.apache.flume.node.MaterializedConfiguration
 
getSinkRunners() - Method in class org.apache.flume.node.SimpleMaterializedConfiguration
 
getSinks() - Method in class org.apache.flume.conf.sink.SinkGroupConfiguration
 
getSinks() - Method in class org.apache.flume.conf.sink.SinkProcessorConfiguration
 
getSinks() - Method in class org.apache.flume.sink.AbstractSinkProcessor
 
getSinks() - Method in class org.apache.flume.sink.AbstractSinkSelector
 
getSinkSet() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
 
getSource() - Method in class org.apache.flume.SourceRunner
 
getSourceClassName() - Method in enum org.apache.flume.conf.source.SourceType
 
getSourceConfigMap() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
 
getSourceConfigurationType() - Method in enum org.apache.flume.conf.source.SourceConfiguration.SourceConfigurationType
 
getSourceContext() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
 
getSourceCounter() - Method in class org.apache.flume.source.SpoolDirectorySource
 
getSourcePort() - Method in class org.apache.flume.source.SyslogTcpSource
 
getSourcePort() - Method in class org.apache.flume.source.SyslogUDPSource
 
getSourceRunners() - Method in interface org.apache.flume.node.MaterializedConfiguration
 
getSourceRunners() - Method in class org.apache.flume.node.SimpleMaterializedConfiguration
 
getSourceSet() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
 
getSpill() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.SpillableString
 
getSpillPayload() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
getSrcChecksum() - Static method in class org.apache.flume.tools.VersionInfo
Get the checksum of the source files from which Flume was built.
getStartException() - Method in class org.apache.flume.source.BasicSourceSemantics
 
getStartTime() - Method in interface org.apache.flume.instrumentation.ChannelCounterMBean
 
getStartTime() - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
Returns when this component was first started
getStartTime() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
 
getStartTime() - Method in interface org.apache.flume.instrumentation.SourceCounterMBean
 
getState() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
getStopTime() - Method in interface org.apache.flume.instrumentation.ChannelCounterMBean
 
getStopTime() - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
Returns when this component was stopped
getStopTime() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
 
getStopTime() - Method in interface org.apache.flume.instrumentation.SourceCounterMBean
 
getString() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.SpillableString
 
getString(String, String) - Method in class org.apache.flume.Context
Gets value mapped to key, returning defaultValue if unmapped.
getString(String) - Method in class org.apache.flume.Context
Gets value mapped to key, returning null if unmapped.
getSubProperties(String) - Method in class org.apache.flume.Context
Get properties which start with a prefix.
getSuccess() - Method in class org.apache.flume.source.scribe.Scribe.Log_result
 
getSuccess() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
 
getSuccess() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
 
getSyslogStatus() - Method in enum org.apache.flume.source.SyslogUtils.SyslogStatus
 
getTakeCount() - Method in class org.apache.flume.channel.file.Log
 
getTarget() - Method in class org.apache.flume.serialization.DurablePositionTracker
 
getTarget() - Method in interface org.apache.flume.serialization.PositionTracker
 
getThriftFieldId() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
 
getThriftFieldId() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
 
getThriftFieldId() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
 
getThriftFieldId() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
 
getThriftFieldId() - Method in enum org.apache.flume.source.scribe.LogEntry._Fields
 
getThriftFieldId() - Method in enum org.apache.flume.source.scribe.Scribe.Log_args._Fields
 
getThriftFieldId() - Method in enum org.apache.flume.source.scribe.Scribe.Log_result._Fields
 
getThriftFieldId() - Method in enum org.apache.flume.thrift.ThriftFlumeEvent._Fields
 
getThriftFieldId() - Method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_args._Fields
 
getThriftFieldId() - Method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_result._Fields
 
getThriftFieldId() - Method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args._Fields
 
getThriftFieldId() - Method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result._Fields
 
getThriftInstance(String, Integer, Integer) - Static method in class org.apache.flume.api.RpcClientFactory
Return an RpcClient that uses Thrift for communicating with the next hop.
getThriftInstance(String, Integer) - Static method in class org.apache.flume.api.RpcClientFactory
Return an RpcClient that uses Thrift for communicating with the next hop.
getThriftInstance(Properties) - Static method in class org.apache.flume.api.RpcClientFactory
Return an RpcClient that uses Thrift for communicating with the next hop.
getTimeout() - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
 
getTimestamp() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
getTimestampKey(String) - Static method in class org.apache.flume.sink.hbase.SimpleRowKeyGenerator
 
getTotalStored() - Method in class org.apache.flume.channel.SpillableMemoryChannel
 
getTransaction() - Method in class org.apache.flume.channel.BasicChannelSemantics
Initializes the channel if it is not already, then checks to see if there is an open transaction for this thread, creating a new one via createTransaction if not.
getTransaction() - Method in interface org.apache.flume.Channel
 
getTransaction() - Method in class org.apache.flume.channel.jdbc.impl.JdbcChannelProviderImpl
 
getTransaction() - Method in class org.apache.flume.channel.jdbc.JdbcChannel
 
getTransaction() - Method in interface org.apache.flume.channel.jdbc.JdbcChannelProvider
 
getTransaction() - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel
 
getTransactionID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
required sfixed64 transactionID = 2;
getTransactionID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
required sfixed64 transactionID = 2;
getTransactionID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeaderOrBuilder
required sfixed64 transactionID = 2;
getType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
required sfixed32 type = 1;
getType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
required sfixed32 type = 1;
getType() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CommitOrBuilder
required sfixed32 type = 1;
getType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
required sfixed32 type = 1;
getType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
required sfixed32 type = 1;
getType() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeaderOrBuilder
required sfixed32 type = 1;
getType() - Method in class org.apache.flume.conf.ComponentConfiguration
 
getType() - Method in interface org.apache.flume.instrumentation.ChannelCounterMBean
 
getType() - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
 
getType() - Method in interface org.apache.flume.instrumentation.SinkCounterMBean
 
getType() - Method in interface org.apache.flume.instrumentation.SourceCounterMBean
 
getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
getUnknownFields() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
getUnsafeMode() - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
 
getUrl() - Static method in class org.apache.flume.tools.VersionInfo
Get the subversion URL for the root Flume directory.
getUser() - Static method in class org.apache.flume.tools.VersionInfo
The user that compiled Flume.
getUUIDKey(String) - Static method in class org.apache.flume.sink.hbase.SimpleRowKeyGenerator
 
getValidationQuery() - Method in enum org.apache.flume.channel.jdbc.DatabaseType
 
getValue() - Method in enum com.cloudera.flume.handlers.thrift.EventStatus
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum com.cloudera.flume.handlers.thrift.Priority
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
required string value = 2;
getValue() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
required string value = 2;
getValue() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeaderOrBuilder
required string value = 2;
getValue() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
 
getValue() - Method in class org.apache.flume.sink.hdfs.SequenceFileSerializer.Record
 
getValue() - Method in enum org.apache.flume.source.scribe.ResultCode
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.flume.thrift.Status
Get the integer value of this enum value, as defined in the Thrift IDL.
getValueBytes() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
required string value = 2;
getValueBytes() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
required string value = 2;
getValueBytes() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeaderOrBuilder
required string value = 2;
getValueClass() - Method in class org.apache.flume.sink.hdfs.HDFSTextSerializer
 
getValueClass() - Method in class org.apache.flume.sink.hdfs.HDFSWritableSerializer
 
getValueClass() - Method in interface org.apache.flume.sink.hdfs.SequenceFileSerializer
 
getValueString() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
 
getVersion() - Method in class org.apache.flume.channel.file.LogFileV3.SequentialReader
 
getVersion() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
required sfixed32 version = 1;
getVersion() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
required sfixed32 version = 1;
getVersion() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
required sfixed32 version = 1;
getVersion() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
required sfixed32 version = 1;
getVersion() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
required sfixed32 version = 1;
getVersion() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
required sfixed32 version = 1;
getVersion() - Static method in class org.apache.flume.tools.VersionInfo
Get the Flume version.
getWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
required sfixed64 writeOrderID = 2;
getWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
required sfixed64 writeOrderID = 2;
getWriteOrderID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
required sfixed64 writeOrderID = 2;
getWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
required sfixed64 writeOrderID = 3;
getWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
required sfixed64 writeOrderID = 3;
getWriteOrderID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeaderOrBuilder
required sfixed64 writeOrderID = 3;
getWriter(String) - Method in class org.apache.flume.sink.hdfs.HDFSWriterFactory
 

H

handleConfigurationEvent(MaterializedConfiguration) - Method in class org.apache.flume.node.Application
 
HANDLER_CLASS - Static variable in class org.apache.flume.sink.solr.morphline.MorphlineSink
 
hasBackupCheckpointPosition() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
optional sfixed64 backupCheckpointPosition = 6;
hasBackupCheckpointPosition() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
optional sfixed64 backupCheckpointPosition = 6;
hasBackupCheckpointPosition() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
optional sfixed64 backupCheckpointPosition = 6;
hasBackupCheckpointWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
optional sfixed64 backupCheckpointWriteOrderID = 7;
hasBackupCheckpointWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
optional sfixed64 backupCheckpointWriteOrderID = 7;
hasBackupCheckpointWriteOrderID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
optional sfixed64 backupCheckpointWriteOrderID = 7;
hasBody() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
required bytes body = 2;
hasBody() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
required bytes body = 2;
hasBody() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventOrBuilder
required bytes body = 2;
hasCheckpointPosition() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
required sfixed64 checkpointPosition = 3;
hasCheckpointPosition() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
required sfixed64 checkpointPosition = 3;
hasCheckpointPosition() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
required sfixed64 checkpointPosition = 3;
hasCheckpointWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
required sfixed64 checkpointWriteOrderID = 4;
hasCheckpointWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
required sfixed64 checkpointWriteOrderID = 4;
hasCheckpointWriteOrderID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
required sfixed64 checkpointWriteOrderID = 4;
hasChecksum() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
optional sfixed64 checksum = 2;
hasChecksum() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
optional sfixed64 checksum = 2;
hasChecksum() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.PutOrBuilder
optional sfixed64 checksum = 2;
hasCipherProvider() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
required string cipherProvider = 1;
hasCipherProvider() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
required string cipherProvider = 1;
hasCipherProvider() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryptionOrBuilder
required string cipherProvider = 1;
hasCount() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
required sfixed32 count = 2;
hasCount() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
required sfixed32 count = 2;
hasCount() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.ActiveLogOrBuilder
required sfixed32 count = 2;
hasEncryption() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
optional .LogFileEncryption encryption = 5;
hasEncryption() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
optional .LogFileEncryption encryption = 5;
hasEncryption() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
optional .LogFileEncryption encryption = 5;
hasEvent() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
required .FlumeEvent event = 1;
hasEvent() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
required .FlumeEvent event = 1;
hasEvent() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.PutOrBuilder
required .FlumeEvent event = 1;
hasFatalError() - Method in class org.apache.flume.source.SpoolDirectorySource
 
hasFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
required sfixed32 fileID = 1;
hasFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
required sfixed32 fileID = 1;
hasFileID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.TakeOrBuilder
required sfixed32 fileID = 1;
hashCode() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
hashCode() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
 
hashCode() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
 
hashCode() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
 
hashCode() - Method in class org.apache.flume.sink.hdfs.KerberosUser
 
hashCode() - Method in class org.apache.flume.source.scribe.LogEntry
 
hashCode() - Method in class org.apache.flume.source.scribe.Scribe.Log_args
 
hashCode() - Method in class org.apache.flume.source.scribe.Scribe.Log_result
 
hashCode() - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
hashCode() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
 
hashCode() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
 
hashCode() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
hashCode() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
 
hasKey() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
required string key = 1;
hasKey() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
required string key = 1;
hasKey() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeaderOrBuilder
required string key = 1;
hasKeyAlias() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
required string keyAlias = 2;
hasKeyAlias() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
required string keyAlias = 2;
hasKeyAlias() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryptionOrBuilder
required string keyAlias = 2;
hasLogFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
required sfixed32 logFileID = 1;
hasLogFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
required sfixed32 logFileID = 1;
hasLogFileID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.ActiveLogOrBuilder
required sfixed32 logFileID = 1;
hasLogFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
required sfixed32 logFileID = 2;
hasLogFileID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
required sfixed32 logFileID = 2;
hasLogFileID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
required sfixed32 logFileID = 2;
hasNext() - Method in class org.apache.flume.util.SpecificOrderIterator
 
hasOffset() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
required sfixed32 offset = 2;
hasOffset() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
required sfixed32 offset = 2;
hasOffset() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.TakeOrBuilder
required sfixed32 offset = 2;
hasParameters() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
optional bytes parameters = 3;
hasParameters() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
optional bytes parameters = 3;
hasParameters() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryptionOrBuilder
optional bytes parameters = 3;
hasQueueHead() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
required sfixed32 queueHead = 4;
hasQueueHead() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
required sfixed32 queueHead = 4;
hasQueueHead() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
required sfixed32 queueHead = 4;
hasQueueSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
required sfixed32 queueSize = 3;
hasQueueSize() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
required sfixed32 queueSize = 3;
hasQueueSize() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
required sfixed32 queueSize = 3;
hasSpill() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.SpillableString
 
hasTransactionID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
required sfixed64 transactionID = 2;
hasTransactionID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
required sfixed64 transactionID = 2;
hasTransactionID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeaderOrBuilder
required sfixed64 transactionID = 2;
hasType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
required sfixed32 type = 1;
hasType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
required sfixed32 type = 1;
hasType() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CommitOrBuilder
required sfixed32 type = 1;
hasType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
required sfixed32 type = 1;
hasType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
required sfixed32 type = 1;
hasType() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeaderOrBuilder
required sfixed32 type = 1;
hasValue() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
required string value = 2;
hasValue() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
required string value = 2;
hasValue() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeaderOrBuilder
required string value = 2;
hasVersion() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
required sfixed32 version = 1;
hasVersion() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
required sfixed32 version = 1;
hasVersion() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
required sfixed32 version = 1;
hasVersion() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
required sfixed32 version = 1;
hasVersion() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
required sfixed32 version = 1;
hasVersion() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataOrBuilder
required sfixed32 version = 1;
hasWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
required sfixed64 writeOrderID = 2;
hasWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
required sfixed64 writeOrderID = 2;
hasWriteOrderID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.CheckpointOrBuilder
required sfixed64 writeOrderID = 2;
hasWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
required sfixed64 writeOrderID = 3;
hasWriteOrderID() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
required sfixed64 writeOrderID = 3;
hasWriteOrderID() - Method in interface org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeaderOrBuilder
required sfixed64 writeOrderID = 3;
HbaseEventSerializer - Interface in org.apache.flume.sink.hbase
Interface for an event serializer which serializes the headers and body of an event to write them to hbase.
HBaseSink - Class in org.apache.flume.sink.hbase
A simple sink which reads events from a channel and writes them to HBase.
HBaseSink() - Constructor for class org.apache.flume.sink.hbase.HBaseSink
 
HBaseSink(Configuration) - Constructor for class org.apache.flume.sink.hbase.HBaseSink
 
HBaseSinkConfigurationConstants - Class in org.apache.flume.sink.hbase
Constants used for configuration of HBaseSink and AsyncHBaseSink
HBaseSinkConfigurationConstants() - Constructor for class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
 
HBaseSinkSecurityManager - Class in org.apache.flume.sink.hbase
Class to handle logging into HBase with the credentials passed in.
HBaseSinkSecurityManager() - Constructor for class org.apache.flume.sink.hbase.HBaseSinkSecurityManager
 
HDFSCompressedDataStream - Class in org.apache.flume.sink.hdfs
 
HDFSCompressedDataStream() - Constructor for class org.apache.flume.sink.hdfs.HDFSCompressedDataStream
 
HDFSDataStream - Class in org.apache.flume.sink.hdfs
 
HDFSDataStream() - Constructor for class org.apache.flume.sink.hdfs.HDFSDataStream
 
HDFSEventSink - Class in org.apache.flume.sink.hdfs
 
HDFSEventSink() - Constructor for class org.apache.flume.sink.hdfs.HDFSEventSink
 
HDFSEventSink(HDFSWriterFactory) - Constructor for class org.apache.flume.sink.hdfs.HDFSEventSink
 
HDFSEventSink.WriterCallback - Interface in org.apache.flume.sink.hdfs
 
HDFSSequenceFile - Class in org.apache.flume.sink.hdfs
 
HDFSSequenceFile() - Constructor for class org.apache.flume.sink.hdfs.HDFSSequenceFile
 
HDFSTextSerializer - Class in org.apache.flume.sink.hdfs
 
HDFSTextSerializer() - Constructor for class org.apache.flume.sink.hdfs.HDFSTextSerializer
 
HDFSTextSerializer.Builder - Class in org.apache.flume.sink.hdfs
 
HDFSTextSerializer.Builder() - Constructor for class org.apache.flume.sink.hdfs.HDFSTextSerializer.Builder
 
HDFSWritableSerializer - Class in org.apache.flume.sink.hdfs
 
HDFSWritableSerializer() - Constructor for class org.apache.flume.sink.hdfs.HDFSWritableSerializer
 
HDFSWritableSerializer.Builder - Class in org.apache.flume.sink.hdfs
 
HDFSWritableSerializer.Builder() - Constructor for class org.apache.flume.sink.hdfs.HDFSWritableSerializer.Builder
 
HDFSWriter - Interface in org.apache.flume.sink.hdfs
 
HDFSWriterFactory - Class in org.apache.flume.sink.hdfs
 
HDFSWriterFactory() - Constructor for class org.apache.flume.sink.hdfs.HDFSWriterFactory
 
HEADER_NAME - Static variable in class org.apache.flume.sink.solr.morphline.UUIDInterceptor
 
HEADER_NAME_LENGTH_THRESHOLD - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
The length of header name in bytes that will be stored inline.
HEADER_NAME_SPILL_MAX_LENGTH - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
The maximum spill size for header names.
HEADER_VALUE_LENGTH_THRESHOLD - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
The length of header value in bytes that will be stored inline.
HEADER_VALUE_SPILL_MAX_LENGTH - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
The maximum spill size for header values.
HeaderAndBodyTextEventSerializer - Class in org.apache.flume.serialization
This class simply writes the body of the event to the output stream and appends a newline after each event.
HeaderAndBodyTextEventSerializer.Builder - Class in org.apache.flume.serialization
 
HeaderAndBodyTextEventSerializer.Builder() - Constructor for class org.apache.flume.serialization.HeaderAndBodyTextEventSerializer.Builder
 
headers - Variable in class org.apache.flume.thrift.ThriftFlumeEvent
 
HEADERS_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
hitChannelException() - Method in class org.apache.flume.source.SpoolDirectorySource
 
host - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
HOST - Static variable in class org.apache.flume.interceptor.HostInterceptor.Constants
 
HOST - Static variable in class org.apache.flume.source.avroLegacy.AvroLegacySource
 
HOST_HEADER - Static variable in class org.apache.flume.interceptor.HostInterceptor.Constants
 
HOST_SELECTOR_RANDOM - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
 
HOST_SELECTOR_ROUND_ROBIN - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
 
HostInfo - Class in org.apache.flume.api
A convenience class that holds the property reference name along with the hostname and port number of a specified host address.
HostInfo(String, String, int) - Constructor for class org.apache.flume.api.HostInfo
 
HostInterceptor - Class in org.apache.flume.interceptor
Simple Interceptor class that sets the host name or IP on all events that are intercepted.
HostInterceptor.Builder - Class in org.apache.flume.interceptor
Builder which builds new instances of the HostInterceptor.
HostInterceptor.Builder() - Constructor for class org.apache.flume.interceptor.HostInterceptor.Builder
 
HostInterceptor.Constants - Class in org.apache.flume.interceptor
 
HostInterceptor.Constants() - Constructor for class org.apache.flume.interceptor.HostInterceptor.Constants
 
HOSTNAMES - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
Comma separated list of hostname:port, if the port is not present the default port '9300' will be used
HTTPBadRequestException - Exception in org.apache.flume.source.http
Exception thrown by an HTTP Handler if the request was not parsed correctly into an event because the request was not in the expected format.
HTTPBadRequestException(String) - Constructor for exception org.apache.flume.source.http.HTTPBadRequestException
 
HTTPBadRequestException(String, Throwable) - Constructor for exception org.apache.flume.source.http.HTTPBadRequestException
 
HTTPBadRequestException(Throwable) - Constructor for exception org.apache.flume.source.http.HTTPBadRequestException
 
HTTPMetricsServer - Class in org.apache.flume.instrumentation.http
A Monitor service implementation that runs a web server on a configurable port and returns the metrics for components in JSON format.
HTTPMetricsServer() - Constructor for class org.apache.flume.instrumentation.http.HTTPMetricsServer
 
HTTPServerConstraintUtil - Class in org.apache.flume.tools
Utility class to impose constraints on Jetty HTTP servers
HTTPSource - Class in org.apache.flume.source.http
A source which accepts Flume Events by HTTP POST and GET.
HTTPSource() - Constructor for class org.apache.flume.source.http.HTTPSource
 
HTTPSourceConfigurationConstants - Class in org.apache.flume.source.http
 
HTTPSourceConfigurationConstants() - Constructor for class org.apache.flume.source.http.HTTPSourceConfigurationConstants
 
HTTPSourceHandler - Interface in org.apache.flume.source.http
 

I

IGNORE_CASE_CONFIG - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
Whether to ignore case when performing regex matches.
IGNORE_PAT - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
Pattern of files to ignore
ignorePattern(String) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
 
increment(String) - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
Atomically increments the current value for this key by one
incrementAndGet(String) - Method in class org.apache.flume.CounterGroup
 
incrementAppendAcceptedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
 
incrementAppendBatchAcceptedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
 
incrementAppendBatchReceivedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
 
incrementAppendReceivedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
 
incrementBatchCompleteCount() - Method in class org.apache.flume.instrumentation.SinkCounter
 
incrementBatchEmptyCount() - Method in class org.apache.flume.instrumentation.SinkCounter
 
incrementBatchUnderflowCount() - Method in class org.apache.flume.instrumentation.SinkCounter
 
incrementConnectionClosedCount() - Method in class org.apache.flume.instrumentation.SinkCounter
 
incrementConnectionCreatedCount() - Method in class org.apache.flume.instrumentation.SinkCounter
 
incrementConnectionFailedCount() - Method in class org.apache.flume.instrumentation.SinkCounter
 
incrementEventAcceptedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
 
incrementEventDrainAttemptCount() - Method in class org.apache.flume.instrumentation.SinkCounter
 
incrementEventDrainSuccessCount() - Method in class org.apache.flume.instrumentation.SinkCounter
 
incrementEventPutAttemptCount() - Method in class org.apache.flume.instrumentation.ChannelCounter
 
incrementEventReceivedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
 
incrementEventTakeAttemptCount() - Method in class org.apache.flume.instrumentation.ChannelCounter
 
incrementPersistedEventCount() - Method in class org.apache.flume.channel.jdbc.impl.JdbcTransactionImpl
 
incrementRemovedEventCount() - Method in class org.apache.flume.channel.jdbc.impl.JdbcTransactionImpl
 
INDENTSTEP - Static variable in class org.apache.flume.conf.FlumeConfiguration
 
INDEX_NAME - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
The name to index the document to, defaults to 'flume'
INDEX_NAME_BUILDER - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
The fully qualified class name of the index name builder the sink should use to determine name of index where the event should be sent.
INDEX_NAME_BUILDER_PREFIX - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
The fully qualified class name of the index name builder the sink should use to determine name of index where the event should be sent.
INDEX_TYPE - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
The type to index the document to, defaults to 'log'
IndexNameBuilder - Interface in org.apache.flume.sink.elasticsearch
 
informFailure(HostInfo) - Method in interface org.apache.flume.api.LoadBalancingRpcClient.HostSelector
 
informFailure(T) - Method in class org.apache.flume.util.OrderSelector
Inform this class of the failure of an object so it can be backed off.
informSinkFailed(Sink) - Method in class org.apache.flume.sink.AbstractSinkSelector
 
informSinkFailed(Sink) - Method in interface org.apache.flume.sink.LoadBalancingSinkProcessor.SinkSelector
 
INGORE_CASE_DEFAULT - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
 
INITIAL_CONTEXT_FACTORY - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
InitialContextFactory - Class in org.apache.flume.source.jms
 
InitialContextFactory() - Constructor for class org.apache.flume.source.jms.InitialContextFactory
 
initialize() - Method in class org.apache.flume.channel.BasicChannelSemantics
Called upon first getTransaction() request, while synchronized on this Channel instance.
initialize() - Method in class org.apache.flume.channel.ChannelProcessor
 
initialize(Context) - Method in class org.apache.flume.channel.jdbc.impl.JdbcChannelProviderImpl
 
initialize(Context) - Method in interface org.apache.flume.channel.jdbc.JdbcChannelProvider
Initializes the channel provider.
initialize() - Method in class org.apache.flume.interceptor.HostInterceptor
 
initialize() - Method in interface org.apache.flume.interceptor.Interceptor
Any initialization / startup needed by the Interceptor.
initialize() - Method in class org.apache.flume.interceptor.InterceptorChain
 
initialize() - Method in class org.apache.flume.interceptor.RegexExtractorInterceptor
 
initialize() - Method in class org.apache.flume.interceptor.RegexFilteringInterceptor
 
initialize() - Method in class org.apache.flume.interceptor.StaticInterceptor
 
initialize() - Method in class org.apache.flume.interceptor.TimestampInterceptor
 
initialize(byte[], byte[]) - Method in interface org.apache.flume.sink.hbase.AsyncHbaseEventSerializer
Initialize the event serializer.
initialize(Event, byte[]) - Method in interface org.apache.flume.sink.hbase.HbaseEventSerializer
Initialize the event serializer.
initialize(Event, byte[]) - Method in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
 
initialize(byte[], byte[]) - Method in class org.apache.flume.sink.hbase.SimpleAsyncHbaseEventSerializer
 
initialize(Event, byte[]) - Method in class org.apache.flume.sink.hbase.SimpleHbaseEventSerializer
 
initialize() - Method in class org.apache.flume.sink.solr.morphline.MorphlineInterceptor
 
initialize() - Method in class org.apache.flume.sink.solr.morphline.UUIDInterceptor
 
initializeRpcClient(Properties) - Method in class org.apache.flume.sink.AbstractRpcSink
Returns a new RpcClient instance configured using the given Properties object.
initializeRpcClient(Properties) - Method in class org.apache.flume.sink.AvroSink
 
initializeRpcClient(Properties) - Method in class org.apache.flume.sink.ThriftSink
 
initialValue() - Method in class org.apache.flume.channel.jdbc.impl.JdbcTransactionFactory
 
INPUT_CHARSET - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
Character set used when reading the input.
inputCharset(String) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
 
intercept(Event) - Method in class org.apache.flume.interceptor.HostInterceptor
Modifies events in-place.
intercept(List<Event>) - Method in class org.apache.flume.interceptor.HostInterceptor
Delegates to HostInterceptor.intercept(Event) in a loop.
intercept(Event) - Method in interface org.apache.flume.interceptor.Interceptor
Interception of a single Event.
intercept(List<Event>) - Method in interface org.apache.flume.interceptor.Interceptor
Interception of a batch of events.
intercept(Event) - Method in class org.apache.flume.interceptor.InterceptorChain
 
intercept(List<Event>) - Method in class org.apache.flume.interceptor.InterceptorChain
 
intercept(Event) - Method in class org.apache.flume.interceptor.RegexExtractorInterceptor
 
intercept(List<Event>) - Method in class org.apache.flume.interceptor.RegexExtractorInterceptor
 
intercept(Event) - Method in class org.apache.flume.interceptor.RegexFilteringInterceptor
 
intercept(List<Event>) - Method in class org.apache.flume.interceptor.RegexFilteringInterceptor
Returns the set of events which pass filters, according to RegexFilteringInterceptor.intercept(Event).
intercept(Event) - Method in class org.apache.flume.interceptor.StaticInterceptor
Modifies events in-place.
intercept(List<Event>) - Method in class org.apache.flume.interceptor.StaticInterceptor
Delegates to StaticInterceptor.intercept(Event) in a loop.
intercept(Event) - Method in class org.apache.flume.interceptor.TimestampInterceptor
Modifies events in-place.
intercept(List<Event>) - Method in class org.apache.flume.interceptor.TimestampInterceptor
intercept(List<Event>) - Method in class org.apache.flume.sink.solr.morphline.MorphlineInterceptor
 
intercept(Event) - Method in class org.apache.flume.sink.solr.morphline.MorphlineInterceptor
 
intercept(Event) - Method in class org.apache.flume.sink.solr.morphline.UUIDInterceptor
 
intercept(List<Event>) - Method in class org.apache.flume.sink.solr.morphline.UUIDInterceptor
 
Interceptor - Interface in org.apache.flume.interceptor
 
Interceptor.Builder - Interface in org.apache.flume.interceptor
Builder implementations MUST have a no-arg constructor
InterceptorBuilderFactory - Class in org.apache.flume.interceptor
Factory used to register instances of Interceptors & their builders, as well as to instantiate the builders.
InterceptorBuilderFactory() - Constructor for class org.apache.flume.interceptor.InterceptorBuilderFactory
 
InterceptorChain - Class in org.apache.flume.interceptor
Implementation of Interceptor that calls a list of other Interceptors serially.
InterceptorChain() - Constructor for class org.apache.flume.interceptor.InterceptorChain
 
InterceptorType - Enum in org.apache.flume.interceptor
 
InterfaceAudience - Class in org.apache.flume.annotations
Annotation to inform users of a package, class or method's intended audience.
InterfaceAudience.LimitedPrivate - Annotation Type in org.apache.flume.annotations
Intended only for the project(s) specified in the annotation.
InterfaceAudience.Private - Annotation Type in org.apache.flume.annotations
Intended for use only within Flume
InterfaceAudience.Public - Annotation Type in org.apache.flume.annotations
Intended for use by any project or application.
InterfaceStability - Class in org.apache.flume.annotations
Annotation to inform users of how much to rely on a particular package, class or method not changing over time.
InterfaceStability() - Constructor for class org.apache.flume.annotations.InterfaceStability
 
InterfaceStability.Evolving - Annotation Type in org.apache.flume.annotations
Evolving, but can break compatibility at minor release (i.e.
InterfaceStability.Stable - Annotation Type in org.apache.flume.annotations
Can evolve while retaining compatibility for minor release boundaries.; can break compatibility only at major release (ie.
InterfaceStability.Unstable - Annotation Type in org.apache.flume.annotations
No guarantee is provided as to reliability or stability across any level of release granularity.
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
 
internalGetFieldAccessorTable() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
IRCSink - Class in org.apache.flume.sink.irc
 
IRCSink() - Constructor for class org.apache.flume.sink.irc.IRCSink
 
IRCSink.IRCConnectionListener - Class in org.apache.flume.sink.irc
 
IRCSink.IRCConnectionListener() - Constructor for class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
isActive() - Method in class org.apache.flume.api.AbstractRpcClient
 
isActive() - Method in class org.apache.flume.api.FailoverRpcClient
 
isActive() - Method in class org.apache.flume.api.LoadBalancingRpcClient
 
isActive() - Method in class org.apache.flume.api.NettyAvroRpcClient
 
isActive() - Method in interface org.apache.flume.api.RpcClient
Returns true if this object appears to be in a usable state, and it returns false if this object is permanently disabled.
isActive() - Method in class org.apache.flume.api.ThriftRpcClient
 
isComponentInErrorState(LifecycleAware) - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
 
isEmpty() - Method in class org.apache.flume.channel.SpillableMemoryChannel.DrainOrderQueue
 
isGanglia3() - Method in class org.apache.flume.instrumentation.GangliaServer
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback.Builder
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter.Builder
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
 
isInitialized() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
isMatch(Event) - Method in class org.apache.flume.sink.solr.morphline.UUIDInterceptor
 
isNotFoundConfigClass() - Method in class org.apache.flume.conf.ComponentConfiguration
 
isOpen() - Method in class org.apache.flume.channel.file.FileChannel
 
isOverflowDisabled() - Method in class org.apache.flume.channel.SpillableMemoryChannel
 
isSecurityEnabled(Configuration) - Static method in class org.apache.flume.sink.hbase.HBaseSinkSecurityManager
Checks if security is enabled for the HBase cluster.
isSet(ThriftFlumeEvent._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftFlumeEventServer.append_args._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftFlumeEventServer.close_args._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftFlumeEventServer.close_result._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LogEntry._Fields) - Method in class org.apache.flume.source.scribe.LogEntry
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Scribe.Log_args._Fields) - Method in class org.apache.flume.source.scribe.Scribe.Log_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Scribe.Log_result._Fields) - Method in class org.apache.flume.source.scribe.Scribe.Log_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftFlumeEvent._Fields) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftSourceProtocol.append_args._Fields) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftSourceProtocol.append_result._Fields) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftSourceProtocol.appendBatch_args._Fields) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftSourceProtocol.appendBatch_result._Fields) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSetBody() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Returns true if field body is set (has been assigned a value) and false otherwise
isSetBody() - Method in class org.apache.flume.thrift.ThriftFlumeEvent
Returns true if field body is set (has been assigned a value) and false otherwise
isSetCategory() - Method in class org.apache.flume.source.scribe.LogEntry
Returns true if field category is set (has been assigned a value) and false otherwise
isSetEvent() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
Returns true if field event is set (has been assigned a value) and false otherwise
isSetEvents() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
Returns true if field events is set (has been assigned a value) and false otherwise
isSetEvt() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Returns true if field evt is set (has been assigned a value) and false otherwise
isSetFields() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Returns true if field fields is set (has been assigned a value) and false otherwise
isSetHeaders() - Method in class org.apache.flume.thrift.ThriftFlumeEvent
Returns true if field headers is set (has been assigned a value) and false otherwise
isSetHost() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Returns true if field host is set (has been assigned a value) and false otherwise
isSetMessage() - Method in class org.apache.flume.source.scribe.LogEntry
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessages() - Method in class org.apache.flume.source.scribe.Scribe.Log_args
Returns true if field messages is set (has been assigned a value) and false otherwise
isSetNanos() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Returns true if field nanos is set (has been assigned a value) and false otherwise
isSetPriority() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Returns true if field priority is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.flume.source.scribe.Scribe.Log_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isShouldBackOff() - Method in class org.apache.flume.util.OrderSelector
 
isStarted() - Method in class org.apache.flume.source.BasicSourceSemantics
 
isUnderReplicated() - Method in class org.apache.flume.sink.hdfs.AbstractHDFSWriter
Contract for subclasses: Call registerCurrentStream() on open, unregisterCurrentStream() on close, and the base class takes care of the rest.
isUnderReplicated() - Method in interface org.apache.flume.sink.hdfs.HDFSWriter
 
isWindows() - Static method in class org.apache.flume.tools.PlatformDetect
Detects whether we are running under Microsoft Windows.

J

JCE_FILE_KEY_PASSWORD_FILE - Static variable in class org.apache.flume.channel.file.encryption.EncryptionConfiguration
Path to key password file is: keys.aliasName.passwordFile
JCE_FILE_KEY_STORE_FILE - Static variable in class org.apache.flume.channel.file.encryption.EncryptionConfiguration
Path to a jceks key store
JCE_FILE_KEY_STORE_PASSWORD_FILE - Static variable in class org.apache.flume.channel.file.encryption.EncryptionConfiguration
Path to a jceks key store password file
JCE_FILE_KEYS - Static variable in class org.apache.flume.channel.file.encryption.EncryptionConfiguration
Space separated list of keys which are needed for the current set of logs plus the one specified in keyAlias
JCEFileKeyProvider - Class in org.apache.flume.channel.file.encryption
 
JCEFileKeyProvider(File, File, Map<String, File>) - Constructor for class org.apache.flume.channel.file.encryption.JCEFileKeyProvider
 
JCEFileKeyProvider.Builder - Class in org.apache.flume.channel.file.encryption
 
JCEFileKeyProvider.Builder() - Constructor for class org.apache.flume.channel.file.encryption.JCEFileKeyProvider.Builder
 
JdbcChannel - Class in org.apache.flume.channel.jdbc
A JDBC based channel implementation.
JdbcChannel() - Constructor for class org.apache.flume.channel.jdbc.JdbcChannel
Instantiates a new JDBC Channel.
JdbcChannelException - Exception in org.apache.flume.channel.jdbc
 
JdbcChannelException(String) - Constructor for exception org.apache.flume.channel.jdbc.JdbcChannelException
 
JdbcChannelException(String, Exception) - Constructor for exception org.apache.flume.channel.jdbc.JdbcChannelException
 
JdbcChannelException(Exception) - Constructor for exception org.apache.flume.channel.jdbc.JdbcChannelException
 
JdbcChannelProvider - Interface in org.apache.flume.channel.jdbc
Service provider interface for JDBC channel providers.
JdbcChannelProviderFactory - Class in org.apache.flume.channel.jdbc
 
JdbcChannelProviderImpl - Class in org.apache.flume.channel.jdbc.impl
 
JdbcChannelProviderImpl() - Constructor for class org.apache.flume.channel.jdbc.impl.JdbcChannelProviderImpl
 
JdbcTransactionFactory - Class in org.apache.flume.channel.jdbc.impl
 
JdbcTransactionFactory(DataSource, JdbcChannelProviderImpl) - Constructor for class org.apache.flume.channel.jdbc.impl.JdbcTransactionFactory
 
JdbcTransactionImpl - Class in org.apache.flume.channel.jdbc.impl
 
JdbcTransactionImpl(DataSource, JdbcTransactionFactory, JdbcChannelProviderImpl) - Constructor for class org.apache.flume.channel.jdbc.impl.JdbcTransactionImpl
 
JMSDestinationLocator - Enum in org.apache.flume.source.jms
 
JMSDestinationType - Enum in org.apache.flume.source.jms
 
JMSMessageConsumerFactory - Class in org.apache.flume.source.jms
 
JMSMessageConsumerFactory() - Constructor for class org.apache.flume.source.jms.JMSMessageConsumerFactory
 
JMSMessageConverter - Interface in org.apache.flume.source.jms
Converts a JMS Message to an Event.
JMSMessageConverter.Builder - Interface in org.apache.flume.source.jms
Implementors of JMSMessageConverter must either provide a suitable builder or implement the Configurable interface.
JMSSource - Class in org.apache.flume.source.jms
 
JMSSource() - Constructor for class org.apache.flume.source.jms.JMSSource
 
JMSSource(JMSMessageConsumerFactory, InitialContextFactory) - Constructor for class org.apache.flume.source.jms.JMSSource
 
JMSSourceConfiguration - Class in org.apache.flume.source.jms
 
JMSSourceConfiguration() - Constructor for class org.apache.flume.source.jms.JMSSourceConfiguration
 
JMXPollUtil - Class in org.apache.flume.instrumentation.util
 
JMXPollUtil() - Constructor for class org.apache.flume.instrumentation.util.JMXPollUtil
 
JSONEvent - Class in org.apache.flume.event
 
JSONEvent() - Constructor for class org.apache.flume.event.JSONEvent
 
JSONHandler - Class in org.apache.flume.source.http
JSONHandler for HTTPSource that accepts an array of events.
JSONHandler() - Constructor for class org.apache.flume.source.http.JSONHandler
 

K

KEEP_ALIVE - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
The length of time we will wait for space available to do a Put.
KEEP_ALIVE - Static variable in class org.apache.flume.channel.SpillableMemoryChannel
file channel setting that is overriden by Spillable Channel
KerberosUser - Class in org.apache.flume.sink.hdfs
Simple Pair class used to define a unique (principal, keyTab) combination.
KerberosUser(String, String) - Constructor for class org.apache.flume.sink.hdfs.KerberosUser
 
key - Variable in class org.apache.flume.channel.file.encryption.CipherProvider.Decryptor.Builder
 
key - Variable in class org.apache.flume.channel.file.encryption.CipherProvider.Encryptor.Builder
 
KEY - Static variable in class org.apache.flume.interceptor.StaticInterceptor.Constants
 
KEY_DEFAULT - Static variable in class org.apache.flume.interceptor.StaticInterceptor.Constants
 
KEY_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
KEY_PROVIDER - Static variable in class org.apache.flume.channel.file.encryption.EncryptionConfiguration
Encryption key provider, default is null.
KEYALIAS_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
KeyProvider - Class in org.apache.flume.channel.file.encryption
 
KeyProvider() - Constructor for class org.apache.flume.channel.file.encryption.KeyProvider
 
KeyProvider.Builder - Interface in org.apache.flume.channel.file.encryption
 
KeyProviderFactory - Class in org.apache.flume.channel.file.encryption
 
KeyProviderFactory() - Constructor for class org.apache.flume.channel.file.encryption.KeyProviderFactory
 
KeyProviderType - Enum in org.apache.flume.channel.file.encryption
 

L

lastSeen - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
lastSeenState - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
length() - Method in interface org.apache.flume.serialization.LengthMeasurable
returns the total length of the stream or file
length() - Method in class org.apache.flume.serialization.ResettableFileInputStream
 
LengthMeasurable - Interface in org.apache.flume.serialization
 
LifecycleAware - Interface in org.apache.flume.lifecycle
An interface implemented by any class that has a defined, stateful, lifecycle.
lifecycleAware - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.MonitorRunnable
 
LifecycleController - Class in org.apache.flume.lifecycle
 
LifecycleController() - Constructor for class org.apache.flume.lifecycle.LifecycleController
 
LifecycleException - Exception in org.apache.flume.lifecycle
 
LifecycleException() - Constructor for exception org.apache.flume.lifecycle.LifecycleException
 
LifecycleException(String) - Constructor for exception org.apache.flume.lifecycle.LifecycleException
 
LifecycleException(String, Throwable) - Constructor for exception org.apache.flume.lifecycle.LifecycleException
 
LifecycleException(Throwable) - Constructor for exception org.apache.flume.lifecycle.LifecycleException
 
LifecycleState - Enum in org.apache.flume.lifecycle
 
LifecycleSupervisor - Class in org.apache.flume.lifecycle
 
LifecycleSupervisor() - Constructor for class org.apache.flume.lifecycle.LifecycleSupervisor
 
LifecycleSupervisor.MonitorRunnable - Class in org.apache.flume.lifecycle
 
LifecycleSupervisor.MonitorRunnable() - Constructor for class org.apache.flume.lifecycle.LifecycleSupervisor.MonitorRunnable
 
LifecycleSupervisor.Status - Class in org.apache.flume.lifecycle
 
LifecycleSupervisor.Status() - Constructor for class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
LifecycleSupervisor.SupervisorPolicy - Class in org.apache.flume.lifecycle
 
LifecycleSupervisor.SupervisorPolicy() - Constructor for class org.apache.flume.lifecycle.LifecycleSupervisor.SupervisorPolicy
 
LifecycleSupervisor.SupervisorPolicy.AlwaysRestartPolicy - Class in org.apache.flume.lifecycle
 
LifecycleSupervisor.SupervisorPolicy.AlwaysRestartPolicy() - Constructor for class org.apache.flume.lifecycle.LifecycleSupervisor.SupervisorPolicy.AlwaysRestartPolicy
 
LifecycleSupervisor.SupervisorPolicy.OnceOnlyPolicy - Class in org.apache.flume.lifecycle
 
LifecycleSupervisor.SupervisorPolicy.OnceOnlyPolicy() - Constructor for class org.apache.flume.lifecycle.LifecycleSupervisor.SupervisorPolicy.OnceOnlyPolicy
 
LineDeserializer - Class in org.apache.flume.serialization
A deserializer that parses text lines from a file.
LineDeserializer.Builder - Class in org.apache.flume.serialization
 
LineDeserializer.Builder() - Constructor for class org.apache.flume.serialization.LineDeserializer.Builder
 
LoadBalancingLog4jAppender - Class in org.apache.flume.clients.log4jappender
Appends Log4j Events to an external Flume client which is decribed by the Log4j configuration file.
LoadBalancingLog4jAppender() - Constructor for class org.apache.flume.clients.log4jappender.LoadBalancingLog4jAppender
 
LoadBalancingRpcClient - Class in org.apache.flume.api
An implementation of RpcClient interface that uses NettyAvroRpcClient instances to load-balance the requests over many different hosts.
LoadBalancingRpcClient() - Constructor for class org.apache.flume.api.LoadBalancingRpcClient
 
LoadBalancingRpcClient.HostSelector - Interface in org.apache.flume.api
 
LoadBalancingSinkProcessor - Class in org.apache.flume.sink
Provides the ability to load-balance flow over multiple sinks.
LoadBalancingSinkProcessor() - Constructor for class org.apache.flume.sink.LoadBalancingSinkProcessor
 
LoadBalancingSinkProcessor.SinkSelector - Interface in org.apache.flume.sink
An interface that allows the LoadBalancingSinkProcessor to use a load-balancing strategy such as round-robin, random distribution etc.
Log - Class in org.apache.flume.channel.file
Stores FlumeEvents on disk and pointers to the events in a in memory queue.
LOG - Static variable in class org.apache.flume.channel.file.Serialization
 
Log(List<LogEntry>, AsyncMethodCallback<Scribe.AsyncClient.Log_call>) - Method in class org.apache.flume.source.scribe.Scribe.AsyncClient
 
Log(List<LogEntry>, AsyncMethodCallback<Scribe.AsyncClient.Log_call>) - Method in interface org.apache.flume.source.scribe.Scribe.AsyncIface
 
Log(List<LogEntry>) - Method in class org.apache.flume.source.scribe.Scribe.Client
 
Log(List<LogEntry>) - Method in interface org.apache.flume.source.scribe.Scribe.Iface
 
LOG - Static variable in class org.apache.flume.tools.FileChannelIntegrityTool
 
Log4jAppender - Class in org.apache.flume.clients.log4jappender
Appends Log4j Events to an external Flume client which is decribed by the Log4j configuration file.
Log4jAppender() - Constructor for class org.apache.flume.clients.log4jappender.Log4jAppender
If this constructor is used programmatically rather than from a log4j conf you must set the port and hostname and then call activateOptions() before calling append().
Log4jAppender(String, int) - Constructor for class org.apache.flume.clients.log4jappender.Log4jAppender
Sets the hostname and port.
Log4jAvroHeaders - Enum in org.apache.flume.clients.log4jappender
 
LogEntry - Class in org.apache.flume.source.scribe
 
LogEntry() - Constructor for class org.apache.flume.source.scribe.LogEntry
 
LogEntry(String, String) - Constructor for class org.apache.flume.source.scribe.LogEntry
 
LogEntry(LogEntry) - Constructor for class org.apache.flume.source.scribe.LogEntry
Performs a deep copy on other.
LogEntry._Fields - Enum in org.apache.flume.source.scribe
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
LogFile - Class in org.apache.flume.channel.file
 
LogFile() - Constructor for class org.apache.flume.channel.file.LogFile
 
LogFile.OperationRecordUpdater - Class in org.apache.flume.channel.file
This is an class meant to be an internal Flume API, and can change at any time.
LogFile.OperationRecordUpdater(File) - Constructor for class org.apache.flume.channel.file.LogFile.OperationRecordUpdater
 
LogFile.SequentialReader - Class in org.apache.flume.channel.file
 
LOGFILEID_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
LOGFILEID_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
LogFileRetryableIOException - Exception in org.apache.flume.channel.file
 
LogFileRetryableIOException() - Constructor for exception org.apache.flume.channel.file.LogFileRetryableIOException
 
LogFileRetryableIOException(String) - Constructor for exception org.apache.flume.channel.file.LogFileRetryableIOException
 
LogFileRetryableIOException(String, Throwable) - Constructor for exception org.apache.flume.channel.file.LogFileRetryableIOException
 
LogFileV3 - Class in org.apache.flume.channel.file
Represents a single data file on disk.
LogFileV3.SequentialReader - Class in org.apache.flume.channel.file
 
LogFileV3.SequentialReader(File, KeyProvider, boolean) - Constructor for class org.apache.flume.channel.file.LogFileV3.SequentialReader
 
LOGGER - Static variable in class org.apache.flume.channel.file.LogFileV3
 
logger - Static variable in class org.apache.flume.sink.elasticsearch.client.ElasticSearchTransportClient
 
logger - Static variable in class org.apache.flume.source.MultiportSyslogTCPSource
 
logger - Static variable in class org.apache.flume.source.ThriftSource
 
LoggerSink - Class in org.apache.flume.sink
A Sink implementation that logs all events received at the INFO level to the org.apache.flume.sink.LoggerSink logger.
LoggerSink() - Constructor for class org.apache.flume.sink.LoggerSink
 
login(Configuration, String, String, String) - Static method in class org.apache.flume.sink.hbase.HBaseSinkSecurityManager
Login the user using the configuration, and the hostname specified to use for logging in.
LogRecord - Class in org.apache.flume.channel.file
 
LogRecord(int, int, TransactionEventRecord) - Constructor for class org.apache.flume.channel.file.LogRecord
 
LogUtils - Class in org.apache.flume.channel.file
 
LogUtils() - Constructor for class org.apache.flume.channel.file.LogUtils
 

M

main(String[]) - Static method in class org.apache.flume.channel.file.CheckpointRebuilder
 
main(String[]) - Static method in class org.apache.flume.channel.file.LogFile
 
main(String[]) - Static method in class org.apache.flume.client.avro.AvroCLIClient
 
main(String[]) - Static method in class org.apache.flume.node.Application
 
main(String[]) - Static method in class org.apache.flume.tools.FlumeToolsMain
 
main(String[]) - Static method in class org.apache.flume.tools.GetJavaProperty
 
main(String[]) - Static method in class org.apache.flume.tools.VersionInfo
 
mark() - Method in class org.apache.flume.serialization.AvroEventDeserializer
 
mark() - Method in interface org.apache.flume.serialization.EventDeserializer
Marks the underlying input stream, indicating that the events previously returned by this EventDeserializer have been successfully committed.
mark() - Method in class org.apache.flume.serialization.LineDeserializer
 
mark() - Method in interface org.apache.flume.serialization.Resettable
Indicate that the current position should be returned to in the case of Resettable.reset() being called.
mark() - Method in class org.apache.flume.serialization.ResettableFileInputStream
 
mark() - Method in class org.apache.flume.serialization.ResettableInputStream
Marks the current position in this input stream.
mark() - Method in class org.apache.flume.sink.solr.morphline.BlobDeserializer
 
markPosition(long) - Method in interface org.apache.flume.serialization.RemoteMarkable
Indicate that the specified position should be returned to in the case of Resettable.reset() being called.
markPosition(long) - Method in class org.apache.flume.serialization.ResettableFileInputStream
 
markRecordAsNoop(long) - Method in class org.apache.flume.channel.file.LogFile.OperationRecordUpdater
 
MaterializedConfiguration - Interface in org.apache.flume.node
MaterializedConfiguration represents the materialization of a Flume properties file.
MAX_BACKOFF - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
 
MAX_BLOB_LENGTH_DEFAULT - Static variable in class org.apache.flume.sink.solr.morphline.BlobDeserializer
 
MAX_BLOB_LENGTH_DEFAULT - Static variable in class org.apache.flume.sink.solr.morphline.BlobHandler
 
MAX_BLOB_LENGTH_KEY - Static variable in class org.apache.flume.sink.solr.morphline.BlobDeserializer
 
MAX_BLOB_LENGTH_KEY - Static variable in class org.apache.flume.sink.solr.morphline.BlobHandler
 
MAX_FILE_SIZE - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
Max file size for data files, cannot exceed the default.
MAX_IO_WORKERS - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
Configuration constants for the NettyAvroRpcClient NioClientSocketChannelFactory
MAXLINE_DFLT - Static variable in class org.apache.flume.serialization.LineDeserializer
 
MAXLINE_KEY - Static variable in class org.apache.flume.serialization.LineDeserializer
 
maxTimeOut - Variable in class org.apache.flume.sink.AbstractSinkSelector
 
MEMORY_CAPACITY - Static variable in class org.apache.flume.channel.SpillableMemoryChannel
Max number of events to be stored in memory
MemoryChannel - Class in org.apache.flume.channel
MemoryChannel is the recommended channel to use when speeds which writing to disk is impractical is required or durability of data is not required.
MemoryChannel() - Constructor for class org.apache.flume.channel.MemoryChannel
 
memQueue - Variable in class org.apache.flume.channel.SpillableMemoryChannel
 
mergeEncryption(ProtosFactory.LogFileEncryption) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
optional .LogFileEncryption encryption = 5;
mergeEvent(ProtosFactory.FlumeEvent) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
required .FlumeEvent event = 1;
mergeFrom(Message) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
 
mergeFrom(ProtosFactory.ActiveLog) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
 
mergeFrom(Message) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
 
mergeFrom(ProtosFactory.Checkpoint) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
 
mergeFrom(Message) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
 
mergeFrom(ProtosFactory.Commit) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
 
mergeFrom(Message) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
 
mergeFrom(ProtosFactory.FlumeEvent) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
 
mergeFrom(Message) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
 
mergeFrom(ProtosFactory.FlumeEventHeader) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
 
mergeFrom(Message) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
 
mergeFrom(ProtosFactory.LogFileEncryption) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
 
mergeFrom(Message) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
 
mergeFrom(ProtosFactory.LogFileMetaData) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
 
mergeFrom(Message) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
 
mergeFrom(ProtosFactory.Put) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
 
mergeFrom(Message) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback.Builder
 
mergeFrom(ProtosFactory.Rollback) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback.Builder
 
mergeFrom(Message) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
 
mergeFrom(ProtosFactory.Take) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
 
mergeFrom(Message) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter.Builder
 
mergeFrom(ProtosFactory.TransactionEventFooter) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter.Builder
 
mergeFrom(Message) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
 
mergeFrom(ProtosFactory.TransactionEventHeader) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
 
message - Variable in class org.apache.flume.source.scribe.LogEntry
 
MESSAGE_SELECTOR - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
messageReceived(ChannelHandlerContext, MessageEvent) - Method in class org.apache.flume.source.SyslogTcpSource.syslogTcpHandler
 
messageReceived(ChannelHandlerContext, MessageEvent) - Method in class org.apache.flume.source.SyslogUDPSource.syslogHandler
 
messages - Variable in class org.apache.flume.source.scribe.Scribe.Log_args
 
METADATA_FILENAME - Static variable in class org.apache.flume.channel.file.Serialization
 
METADATA_TMP_FILENAME - Static variable in class org.apache.flume.channel.file.Serialization
 
metaDataMap - Static variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
metaDataMap - Static variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
 
metaDataMap - Static variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
 
metaDataMap - Static variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
 
metaDataMap - Static variable in class org.apache.flume.source.scribe.LogEntry
 
metaDataMap - Static variable in class org.apache.flume.source.scribe.Scribe.Log_args
 
metaDataMap - Static variable in class org.apache.flume.source.scribe.Scribe.Log_result
 
metaDataMap - Static variable in class org.apache.flume.thrift.ThriftFlumeEvent
 
metaDataMap - Static variable in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
 
metaDataMap - Static variable in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
 
metaDataMap - Static variable in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
metaDataMap - Static variable in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
 
MIN_SIZE - Static variable in class org.apache.flume.source.SyslogUtils
 
MINIMUM_REQUIRED_SPACE - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
 
MonitoredCounterGroup - Class in org.apache.flume.instrumentation
Used for keeping track of internal metrics using atomic integers
MonitoredCounterGroup(MonitoredCounterGroup.Type, String, String...) - Constructor for class org.apache.flume.instrumentation.MonitoredCounterGroup
 
MonitoredCounterGroup.Type - Enum in org.apache.flume.instrumentation
Component Enum Constants Used by each component's constructor to distinguish which type the component is.
MonitoringType - Enum in org.apache.flume.instrumentation
Enum for Monitoring types.
MonitorService - Interface in org.apache.flume.instrumentation
Interface that any monitoring service should implement.
monitorService - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.MonitorRunnable
 
MORPHLINE_FILE_PARAM - Static variable in class org.apache.flume.sink.solr.morphline.MorphlineHandlerImpl
 
MORPHLINE_ID_PARAM - Static variable in class org.apache.flume.sink.solr.morphline.MorphlineHandlerImpl
 
MORPHLINE_VARIABLE_PARAM - Static variable in class org.apache.flume.sink.solr.morphline.MorphlineHandlerImpl
Morphline variables can be passed from flume.conf to the morphline, e.g.: agent.sinks.solrSink.morphlineVariable.zkHost=127.0.0.1:2181/solr
MorphlineHandler - Interface in org.apache.flume.sink.solr.morphline
Interface to load Flume events into Solr
MorphlineHandlerImpl - Class in org.apache.flume.sink.solr.morphline
A MorphlineHandler that processes it's events using a morphline Command chain.
MorphlineHandlerImpl() - Constructor for class org.apache.flume.sink.solr.morphline.MorphlineHandlerImpl
 
MorphlineInterceptor - Class in org.apache.flume.sink.solr.morphline
Flume Interceptor that executes a morphline on events that are intercepted.
MorphlineInterceptor(Context) - Constructor for class org.apache.flume.sink.solr.morphline.MorphlineInterceptor
 
MorphlineInterceptor.Builder - Class in org.apache.flume.sink.solr.morphline
Builder implementations MUST have a public no-arg constructor
MorphlineInterceptor.Builder() - Constructor for class org.apache.flume.sink.solr.morphline.MorphlineInterceptor.Builder
 
MorphlineSink - Class in org.apache.flume.sink.solr.morphline
Flume sink that extracts search documents from Flume events and processes them using a morphline Command chain.
MorphlineSink() - Constructor for class org.apache.flume.sink.solr.morphline.MorphlineSink
 
MorphlineSink(MorphlineHandler) - Constructor for class org.apache.flume.sink.solr.morphline.MorphlineSink
For testing only
MorphlineSolrSink - Class in org.apache.flume.sink.solr.morphline
Flume sink that extracts search documents from Flume events, processes them using a morphline Command chain, and loads them into Apache Solr.
MorphlineSolrSink() - Constructor for class org.apache.flume.sink.solr.morphline.MorphlineSolrSink
 
MorphlineSolrSink(MorphlineHandler) - Constructor for class org.apache.flume.sink.solr.morphline.MorphlineSolrSink
For testing only
MultiplexingChannelSelector - Class in org.apache.flume.channel
 
MultiplexingChannelSelector() - Constructor for class org.apache.flume.channel.MultiplexingChannelSelector
 
MultiportSyslogTCPSource - Class in org.apache.flume.source
 
MultiportSyslogTCPSource() - Constructor for class org.apache.flume.source.MultiportSyslogTCPSource
 
MySQLSchemaHandler - Class in org.apache.flume.channel.jdbc.impl
 
MySQLSchemaHandler(DataSource) - Constructor for class org.apache.flume.channel.jdbc.impl.MySQLSchemaHandler
 

N

NamedComponent - Interface in org.apache.flume
Enables a component to be tagged with a name so that it can be referred to uniquely within the configuration system.
nanos - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
NANOS - Static variable in class org.apache.flume.source.avroLegacy.AvroLegacySource
 
NetcatSource - Class in org.apache.flume.source
A netcat-like source that listens on a given port and turns each line of text into an event.
NetcatSource() - Constructor for class org.apache.flume.source.NetcatSource
 
NetcatSourceConfigurationConstants - Class in org.apache.flume.source
 
NetcatSourceConfigurationConstants() - Constructor for class org.apache.flume.source.NetcatSourceConfigurationConstants
 
NettyAvroRpcClient - Class in org.apache.flume.api
Avro/Netty implementation of RpcClient.
NettyAvroRpcClient() - Constructor for class org.apache.flume.api.NettyAvroRpcClient
This constructor is intended to be called from RpcClientFactory.
newBuilder() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
newBuilder(ProtosFactory.ActiveLog) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
newBuilder() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
newBuilder(ProtosFactory.Checkpoint) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
newBuilder() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
newBuilder(ProtosFactory.Commit) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
newBuilder() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
newBuilder(ProtosFactory.FlumeEvent) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
newBuilder() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
newBuilder(ProtosFactory.FlumeEventHeader) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
newBuilder() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
newBuilder(ProtosFactory.LogFileEncryption) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
newBuilder() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
newBuilder(ProtosFactory.LogFileMetaData) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
newBuilder() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
newBuilder(ProtosFactory.Put) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
newBuilder() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
newBuilder(ProtosFactory.Rollback) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
newBuilder() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
newBuilder(ProtosFactory.Take) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
newBuilder() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
newBuilder(ProtosFactory.TransactionEventFooter) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
newBuilder() - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
newBuilder(ProtosFactory.TransactionEventHeader) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
newBuilderForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
newBuilderForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
newBuilderForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
newBuilderForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
newBuilderForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
newBuilderForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
newBuilderForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
newBuilderForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
newBuilderForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
newBuilderForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
newBuilderForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
newBuilderForType() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
newDecryptorBuilder() - Method in class org.apache.flume.channel.file.encryption.AESCTRNoPaddingProvider
 
newDecryptorBuilder() - Method in class org.apache.flume.channel.file.encryption.CipherProvider
 
newEncryptorBuilder() - Method in class org.apache.flume.channel.file.encryption.AESCTRNoPaddingProvider
 
newEncryptorBuilder() - Method in class org.apache.flume.channel.file.encryption.CipherProvider
 
newInstance(String) - Static method in class org.apache.flume.interceptor.InterceptorBuilderFactory
Instantiate specified class, either alias or fully-qualified class name.
NEWLINE - Static variable in class org.apache.flume.conf.FlumeConfiguration
 
next() - Method in class org.apache.flume.channel.file.LogFile.SequentialReader
 
next() - Static method in class org.apache.flume.channel.file.TransactionIDOracle
 
next() - Static method in class org.apache.flume.channel.file.WriteOrderOracle
 
next() - Method in class org.apache.flume.util.SpecificOrderIterator
 
nextFile() - Method in class org.apache.flume.formatter.output.PathManager
 
nonce - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
 
NoopRecordException - Exception in org.apache.flume.channel.file
 
NoopRecordException() - Constructor for exception org.apache.flume.channel.file.NoopRecordException
 
NoopRecordException(String) - Constructor for exception org.apache.flume.channel.file.NoopRecordException
 
NoopRecordException(String, Throwable) - Constructor for exception org.apache.flume.channel.file.NoopRecordException
 
NullSink - Class in org.apache.flume.sink
A Sink implementation that simply discards all events it receives.
NullSink() - Constructor for class org.apache.flume.sink.NullSink
 

O

offset - Variable in class org.apache.flume.instrumentation.GangliaServer
 
OFFSET_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
OG_EVENT - Static variable in class org.apache.flume.source.avroLegacy.AvroLegacySource
 
OLD_CONFIG_CREATE_FK - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
Deprecated.
OLD_CONFIG_CREATE_INDEX - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
OLD_CONFIG_CREATE_SCHEMA - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
OLD_CONFIG_DATABASE_TYPE - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
OLD_CONFIG_JDBC_DRIVER_CLASS - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
OLD_CONFIG_JDBC_PROPS_FILE - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
OLD_CONFIG_JDBC_SYSPROP_PREFIX - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
OLD_CONFIG_MAX_CAPACITY - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
OLD_CONFIG_MAX_CONNECTIONS - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
OLD_CONFIG_PASSWORD - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
Deprecated.
OLD_CONFIG_TX_ISOLATION_LEVEL - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
OLD_CONFIG_URL - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
Deprecated.
OLD_CONFIG_USERNAME - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
Deprecated.
OLD_METADATA_FILENAME - Static variable in class org.apache.flume.channel.file.Serialization
 
onBatchStart() - Method in interface org.apache.flume.sink.hbase.BatchAware
 
onDeletionNotice(StatusDeletionNotice) - Method in class org.apache.flume.source.twitter.TwitterSource
 
onDisconnected() - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onError(String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onError(int, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onException(Exception) - Method in class org.apache.flume.source.twitter.TwitterSource
 
onInvite(String, IRCUser, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onJoin(String, IRCUser) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onKick(String, IRCUser, String, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onMode(IRCUser, String, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onMode(String, IRCUser, IRCModeParser) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onNick(IRCUser, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onNotice(String, IRCUser, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onPart(String, IRCUser, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onPing(String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onPrivmsg(String, IRCUser, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onQuit(IRCUser, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onRegistered() - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onReply(int, String, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onScrubGeo(long, long) - Method in class org.apache.flume.source.twitter.TwitterSource
 
onStallWarning(StallWarning) - Method in class org.apache.flume.source.twitter.TwitterSource
 
onStatus(Status) - Method in class org.apache.flume.source.twitter.TwitterSource
 
onTopic(String, IRCUser, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onTrackLimitationNotice(int) - Method in class org.apache.flume.source.twitter.TwitterSource
 
OP_EOF - Static variable in class org.apache.flume.channel.file.LogFile
 
OP_NOOP - Static variable in class org.apache.flume.channel.file.LogFile
 
OP_RECORD - Static variable in class org.apache.flume.channel.file.LogFile
 
open(String) - Method in class org.apache.flume.sink.hdfs.HDFSCompressedDataStream
 
open(String, CompressionCodec, SequenceFile.CompressionType) - Method in class org.apache.flume.sink.hdfs.HDFSCompressedDataStream
 
open(String) - Method in class org.apache.flume.sink.hdfs.HDFSDataStream
 
open(String, CompressionCodec, SequenceFile.CompressionType) - Method in class org.apache.flume.sink.hdfs.HDFSDataStream
 
open(String) - Method in class org.apache.flume.sink.hdfs.HDFSSequenceFile
 
open(String, CompressionCodec, SequenceFile.CompressionType) - Method in class org.apache.flume.sink.hdfs.HDFSSequenceFile
 
open(Path, CompressionCodec, SequenceFile.CompressionType, Configuration, FileSystem) - Method in class org.apache.flume.sink.hdfs.HDFSSequenceFile
 
open(String) - Method in interface org.apache.flume.sink.hdfs.HDFSWriter
 
open(String, CompressionCodec, SequenceFile.CompressionType) - Method in interface org.apache.flume.sink.hdfs.HDFSWriter
 
OrderSelector<T> - Class in org.apache.flume.util
A basic implementation of an order selector that implements a simple exponential backoff algorithm.
OrderSelector(boolean) - Constructor for class org.apache.flume.util.OrderSelector
 
org.apache.flume - package org.apache.flume
 
org.apache.flume.agent.embedded - package org.apache.flume.agent.embedded
This package provides Flume users the ability to embed simple agents in applications.
org.apache.flume.annotations - package org.apache.flume.annotations
 
org.apache.flume.api - package org.apache.flume.api
 
org.apache.flume.channel - package org.apache.flume.channel
 
org.apache.flume.channel.file - package org.apache.flume.channel.file
 
org.apache.flume.channel.file.encryption - package org.apache.flume.channel.file.encryption
 
org.apache.flume.channel.file.proto - package org.apache.flume.channel.file.proto
 
org.apache.flume.channel.jdbc - package org.apache.flume.channel.jdbc
 
org.apache.flume.channel.jdbc.impl - package org.apache.flume.channel.jdbc.impl
 
org.apache.flume.client.avro - package org.apache.flume.client.avro
 
org.apache.flume.clients.log4jappender - package org.apache.flume.clients.log4jappender
 
org.apache.flume.conf - package org.apache.flume.conf
 
org.apache.flume.conf.channel - package org.apache.flume.conf.channel
 
org.apache.flume.conf.sink - package org.apache.flume.conf.sink
 
org.apache.flume.conf.source - package org.apache.flume.conf.source
 
org.apache.flume.event - package org.apache.flume.event
 
org.apache.flume.formatter.output - package org.apache.flume.formatter.output
 
org.apache.flume.instrumentation - package org.apache.flume.instrumentation
 
org.apache.flume.instrumentation.http - package org.apache.flume.instrumentation.http
 
org.apache.flume.instrumentation.util - package org.apache.flume.instrumentation.util
 
org.apache.flume.interceptor - package org.apache.flume.interceptor
 
org.apache.flume.lifecycle - package org.apache.flume.lifecycle
 
org.apache.flume.node - package org.apache.flume.node
 
org.apache.flume.serialization - package org.apache.flume.serialization
 
org.apache.flume.sink - package org.apache.flume.sink
 
org.apache.flume.sink.elasticsearch - package org.apache.flume.sink.elasticsearch
 
org.apache.flume.sink.elasticsearch.client - package org.apache.flume.sink.elasticsearch.client
 
org.apache.flume.sink.hbase - package org.apache.flume.sink.hbase
 
org.apache.flume.sink.hdfs - package org.apache.flume.sink.hdfs
 
org.apache.flume.sink.irc - package org.apache.flume.sink.irc
 
org.apache.flume.sink.solr.morphline - package org.apache.flume.sink.solr.morphline
 
org.apache.flume.source - package org.apache.flume.source
 
org.apache.flume.source.avroLegacy - package org.apache.flume.source.avroLegacy
 
org.apache.flume.source.http - package org.apache.flume.source.http
 
org.apache.flume.source.jms - package org.apache.flume.source.jms
 
org.apache.flume.source.scribe - package org.apache.flume.source.scribe
 
org.apache.flume.source.thriftLegacy - package org.apache.flume.source.thriftLegacy
 
org.apache.flume.source.twitter - package org.apache.flume.source.twitter
 
org.apache.flume.thrift - package org.apache.flume.thrift
 
org.apache.flume.tools - package org.apache.flume.tools
 
org.apache.flume.util - package org.apache.flume.util
 
OUT_CHARSET_KEY - Static variable in class org.apache.flume.serialization.LineDeserializer
 
OVERFLOW_CAPACITY - Static variable in class org.apache.flume.channel.SpillableMemoryChannel
max number of events in overflow.
OVERFLOW_DEACTIVATION_THRESHOLD - Static variable in class org.apache.flume.channel.SpillableMemoryChannel
Internal use only.
OVERFLOW_TIMEOUT - Static variable in class org.apache.flume.channel.SpillableMemoryChannel
Seconds to wait before enabling disk overflow when memory fills up

P

parameters - Variable in class org.apache.flume.channel.file.encryption.CipherProvider.Decryptor.Builder
 
PARAMETERS_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
parseDelimitedFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
parseFrom(ByteString) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
parseFrom(byte[]) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
parseFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
parseFrom(CodedInputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
parseFrom(ByteString) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
parseFrom(byte[]) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
parseFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
parseFrom(CodedInputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
parseFrom(ByteString) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
parseFrom(byte[]) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
parseFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
parseFrom(CodedInputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
parseFrom(ByteString) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
parseFrom(byte[]) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
parseFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
parseFrom(CodedInputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
parseFrom(ByteString) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
parseFrom(byte[]) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
parseFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
parseFrom(CodedInputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
parseFrom(ByteString) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
parseFrom(byte[]) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
parseFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
parseFrom(CodedInputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
parseFrom(ByteString) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
parseFrom(byte[]) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
parseFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
parseFrom(CodedInputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
parseFrom(ByteString) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
parseFrom(byte[]) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
parseFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
parseFrom(CodedInputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
parseFrom(ByteString) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
parseFrom(byte[]) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
parseFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
parseFrom(CodedInputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
parseFrom(ByteString) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
parseFrom(byte[]) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
parseFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
parseFrom(CodedInputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
parseFrom(ByteString) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
parseFrom(byte[]) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
parseFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
parseFrom(CodedInputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
parseFrom(ByteString) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
parseFrom(byte[]) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
parseFrom(InputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
parseFrom(CodedInputStream) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
parseMessage(String, Charset, boolean) - Method in class org.apache.flume.source.SyslogParser
Parses a Flume Event out of a syslog message string.
PARSER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
PARSER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
PARSER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
PARSER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
PARSER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
PARSER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
PARSER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
PARSER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
PARSER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
PARSER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
PARSER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
PARSER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
parseRfc3164Time(String) - Method in class org.apache.flume.source.SyslogParser
Parse the RFC3164 date format.
parseRfc5424Date(String) - Method in class org.apache.flume.source.SyslogParser
Parse date in RFC 5424 format.
PASSWORD_FILE - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
PathManager - Class in org.apache.flume.formatter.output
 
PathManager() - Constructor for class org.apache.flume.formatter.output.PathManager
 
PAYLOAD_LENGTH_THRESHOLD - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
The length for payload bytes that will be stored inline.
PersistableEvent - Class in org.apache.flume.channel.jdbc.impl
 
PersistableEvent(String, Event) - Constructor for class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
PersistableEvent.Builder - Class in org.apache.flume.channel.jdbc.impl
 
PersistableEvent.Builder(String, long) - Constructor for class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
 
PersistableEvent.HeaderEntry - Class in org.apache.flume.channel.jdbc.impl
 
PersistableEvent.HeaderEntry(String, String) - Constructor for class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
 
PersistableEvent.SpillableString - Class in org.apache.flume.channel.jdbc.impl
 
PersistableEvent.SpillableString(String, int) - Constructor for class org.apache.flume.channel.jdbc.impl.PersistableEvent.SpillableString
 
persistEvent(String, Event) - Method in class org.apache.flume.channel.jdbc.impl.JdbcChannelProviderImpl
 
persistEvent(String, Event) - Method in interface org.apache.flume.channel.jdbc.JdbcChannelProvider
Writes the event to the persistent store.
PlatformDetect - Class in org.apache.flume.tools
Utilities for platform & operating system detection
PlatformDetect() - Constructor for class org.apache.flume.tools.PlatformDetect
 
POLL_TIMEOUT - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
POLL_TIMEOUT_DEFAULT - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
PollableSource - Interface in org.apache.flume
A Source that requires an external driver to poll to determine whether there are events that are available to ingest from the source.
PollableSource.Status - Enum in org.apache.flume
 
PollableSourceRunner - Class in org.apache.flume.source
An implementation of SourceRunner that can drive a PollableSource.
PollableSourceRunner() - Constructor for class org.apache.flume.source.PollableSourceRunner
 
PollableSourceRunner.PollingRunner - Class in org.apache.flume.source
 
PollableSourceRunner.PollingRunner() - Constructor for class org.apache.flume.source.PollableSourceRunner.PollingRunner
 
PollingPropertiesFileConfigurationProvider - Class in org.apache.flume.node
 
PollingPropertiesFileConfigurationProvider(String, File, EventBus, int) - Constructor for class org.apache.flume.node.PollingPropertiesFileConfigurationProvider
 
PollingPropertiesFileConfigurationProvider.FileWatcherRunnable - Class in org.apache.flume.node
 
PollingPropertiesFileConfigurationProvider.FileWatcherRunnable(File, CounterGroup) - Constructor for class org.apache.flume.node.PollingPropertiesFileConfigurationProvider.FileWatcherRunnable
 
populateAvroHeaders(Map<String, String>, Schema, Object) - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
 
PositionTracker - Interface in org.apache.flume.serialization
Defines an interface for tracking the offset position in a target file.
PREFIX - Static variable in class org.apache.flume.channel.file.Log
 
PREFIX - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
PREFIX_NAME - Static variable in class org.apache.flume.sink.solr.morphline.UUIDInterceptor
 
prepareIndexRequest(IndexRequestBuilder, String, String, Event) - Method in class org.apache.flume.sink.elasticsearch.AbstractElasticSearchIndexRequestBuilderFactory
Prepares an ElasticSearch IndexRequestBuilder instance
prepareIndexRequest(IndexRequestBuilder, String, String, Event) - Method in class org.apache.flume.sink.elasticsearch.EventSerializerIndexRequestBuilderFactory
 
PRESERVE - Static variable in class org.apache.flume.interceptor.HostInterceptor.Constants
 
PRESERVE - Static variable in class org.apache.flume.interceptor.StaticInterceptor.Constants
 
PRESERVE - Static variable in class org.apache.flume.interceptor.TimestampInterceptor.Constants
 
PRESERVE_DEFAULT - Static variable in class org.apache.flume.interceptor.StaticInterceptor.Constants
 
PRESERVE_DFLT - Static variable in class org.apache.flume.interceptor.HostInterceptor.Constants
 
PRESERVE_DFLT - Static variable in class org.apache.flume.interceptor.TimestampInterceptor.Constants
 
PRESERVE_EXISTING_NAME - Static variable in class org.apache.flume.sink.solr.morphline.UUIDInterceptor
 
Priority - Enum in com.cloudera.flume.handlers.thrift
 
priority - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
PRIORITY - Static variable in class org.apache.flume.source.avroLegacy.AvroLegacySource
 
process() - Method in interface org.apache.flume.PollableSource
Attempt to pull an item from the source, sending it to the channel.
process() - Method in class org.apache.flume.sink.AbstractRpcSink
 
process() - Method in class org.apache.flume.sink.DefaultSinkProcessor
 
process() - Method in class org.apache.flume.sink.elasticsearch.ElasticSearchSink
 
process() - Method in class org.apache.flume.sink.FailoverSinkProcessor
 
process() - Method in class org.apache.flume.sink.hbase.AsyncHBaseSink
 
process() - Method in class org.apache.flume.sink.hbase.HBaseSink
 
process() - Method in class org.apache.flume.sink.hdfs.HDFSEventSink
Pull events out of channel and send it to HDFS.
process() - Method in class org.apache.flume.sink.irc.IRCSink
 
process() - Method in class org.apache.flume.sink.LoadBalancingSinkProcessor
 
process() - Method in class org.apache.flume.sink.LoggerSink
 
process() - Method in class org.apache.flume.sink.NullSink
 
process() - Method in interface org.apache.flume.Sink
Requests the sink to attempt to consume data from attached channel
process() - Method in class org.apache.flume.sink.RollingFileSink
 
process(Event) - Method in interface org.apache.flume.sink.solr.morphline.MorphlineHandler
Loads the given event into Solr
process(Event) - Method in class org.apache.flume.sink.solr.morphline.MorphlineHandlerImpl
 
process() - Method in class org.apache.flume.sink.solr.morphline.MorphlineSink
 
process() - Method in interface org.apache.flume.SinkProcessor
Handle a request to poll the owned sinks.
process() - Method in class org.apache.flume.source.AbstractPollableSource
 
process() - Method in class org.apache.flume.source.SequenceGeneratorSource
 
process() - Method in class org.apache.flume.source.StressSource
 
processEvent(Event) - Method in class org.apache.flume.channel.ChannelProcessor
Attempts to put the given event into each configured channel.
processEventBatch(List<Event>) - Method in class org.apache.flume.channel.ChannelProcessor
Attempts to put the given events into each configured channel.
PropertiesFileConfigurationProvider - Class in org.apache.flume.node
A configuration provider that uses properties file for specifying configuration.
PropertiesFileConfigurationProvider(String, File) - Constructor for class org.apache.flume.node.PropertiesFileConfigurationProvider
 
ProtosFactory - Class in org.apache.flume.channel.file.proto
 
ProtosFactory.ActiveLog - Class in org.apache.flume.channel.file.proto
Protobuf type ActiveLog
ProtosFactory.ActiveLog.Builder - Class in org.apache.flume.channel.file.proto
Protobuf type ActiveLog
ProtosFactory.ActiveLogOrBuilder - Interface in org.apache.flume.channel.file.proto
 
ProtosFactory.Checkpoint - Class in org.apache.flume.channel.file.proto
Protobuf type Checkpoint
ProtosFactory.Checkpoint.Builder - Class in org.apache.flume.channel.file.proto
Protobuf type Checkpoint
ProtosFactory.CheckpointOrBuilder - Interface in org.apache.flume.channel.file.proto
 
ProtosFactory.Commit - Class in org.apache.flume.channel.file.proto
Protobuf type Commit
ProtosFactory.Commit.Builder - Class in org.apache.flume.channel.file.proto
Protobuf type Commit
ProtosFactory.CommitOrBuilder - Interface in org.apache.flume.channel.file.proto
 
ProtosFactory.FlumeEvent - Class in org.apache.flume.channel.file.proto
Protobuf type FlumeEvent
ProtosFactory.FlumeEvent.Builder - Class in org.apache.flume.channel.file.proto
Protobuf type FlumeEvent
ProtosFactory.FlumeEventHeader - Class in org.apache.flume.channel.file.proto
Protobuf type FlumeEventHeader
ProtosFactory.FlumeEventHeader.Builder - Class in org.apache.flume.channel.file.proto
Protobuf type FlumeEventHeader
ProtosFactory.FlumeEventHeaderOrBuilder - Interface in org.apache.flume.channel.file.proto
 
ProtosFactory.FlumeEventOrBuilder - Interface in org.apache.flume.channel.file.proto
 
ProtosFactory.LogFileEncryption - Class in org.apache.flume.channel.file.proto
Protobuf type LogFileEncryption
ProtosFactory.LogFileEncryption.Builder - Class in org.apache.flume.channel.file.proto
Protobuf type LogFileEncryption
ProtosFactory.LogFileEncryptionOrBuilder - Interface in org.apache.flume.channel.file.proto
 
ProtosFactory.LogFileMetaData - Class in org.apache.flume.channel.file.proto
Protobuf type LogFileMetaData
ProtosFactory.LogFileMetaData.Builder - Class in org.apache.flume.channel.file.proto
Protobuf type LogFileMetaData
ProtosFactory.LogFileMetaDataOrBuilder - Interface in org.apache.flume.channel.file.proto
 
ProtosFactory.Put - Class in org.apache.flume.channel.file.proto
Protobuf type Put
ProtosFactory.Put.Builder - Class in org.apache.flume.channel.file.proto
Protobuf type Put
ProtosFactory.PutOrBuilder - Interface in org.apache.flume.channel.file.proto
 
ProtosFactory.Rollback - Class in org.apache.flume.channel.file.proto
Protobuf type Rollback
ProtosFactory.Rollback.Builder - Class in org.apache.flume.channel.file.proto
Protobuf type Rollback
ProtosFactory.RollbackOrBuilder - Interface in org.apache.flume.channel.file.proto
 
ProtosFactory.Take - Class in org.apache.flume.channel.file.proto
Protobuf type Take
ProtosFactory.Take.Builder - Class in org.apache.flume.channel.file.proto
Protobuf type Take
ProtosFactory.TakeOrBuilder - Interface in org.apache.flume.channel.file.proto
 
ProtosFactory.TransactionEventFooter - Class in org.apache.flume.channel.file.proto
Protobuf type TransactionEventFooter
ProtosFactory.TransactionEventFooter.Builder - Class in org.apache.flume.channel.file.proto
Protobuf type TransactionEventFooter
ProtosFactory.TransactionEventFooterOrBuilder - Interface in org.apache.flume.channel.file.proto
 
ProtosFactory.TransactionEventHeader - Class in org.apache.flume.channel.file.proto
Protobuf type TransactionEventHeader
ProtosFactory.TransactionEventHeader.Builder - Class in org.apache.flume.channel.file.proto
Protobuf type TransactionEventHeader
ProtosFactory.TransactionEventHeaderOrBuilder - Interface in org.apache.flume.channel.file.proto
 
PROVIDER_URL - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
PseudoTxnMemoryChannel - Class in org.apache.flume.channel
A capacity-capped Channel implementation that supports in-memory buffering and delivery of events.
PseudoTxnMemoryChannel() - Constructor for class org.apache.flume.channel.PseudoTxnMemoryChannel
 
PseudoTxnMemoryChannel.NoOpTransaction - Class in org.apache.flume.channel
A no-op transaction implementation that does nothing at all.
PseudoTxnMemoryChannel.NoOpTransaction() - Constructor for class org.apache.flume.channel.PseudoTxnMemoryChannel.NoOpTransaction
 
put(Event) - Method in class org.apache.flume.agent.embedded.EmbeddedAgent
Adds event to the channel owned by the agent.
put(Event) - Method in class org.apache.flume.agent.embedded.EmbeddedSource
 
put(Event) - Method in class org.apache.flume.channel.BasicChannelSemantics
Ensures that a transaction exists for this thread and then delegates the put to the thread's BasicTransactionSemantics instance.
put(Event) - Method in class org.apache.flume.channel.BasicTransactionSemantics
The method to which BasicChannelSemantics delegates calls to put.
put(Channel, Event) - Static method in class org.apache.flume.channel.ChannelUtils
A convenience method for single-event put transactions.
put(Channel, Collection<Event>) - Static method in class org.apache.flume.channel.ChannelUtils
A convenience method for multiple-event put transactions.
put(Event) - Method in class org.apache.flume.channel.jdbc.JdbcChannel
 
put(Event) - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel
 
put(Event) - Method in interface org.apache.flume.Channel
Puts the given event into the channel.
put(String, String) - Method in class org.apache.flume.Context
Associates the specified value with the specified key in this context.
putAll(List<Event>) - Method in class org.apache.flume.agent.embedded.EmbeddedAgent
Adds events to the channel owned by the agent.
putAll(List<Event>) - Method in class org.apache.flume.agent.embedded.EmbeddedSource
 
putAll(Map<String, String>) - Method in class org.apache.flume.Context
Associates all of the given map's keys and values in the Context.
putFirstOverflow(Integer) - Method in class org.apache.flume.channel.SpillableMemoryChannel.DrainOrderQueue
 
putFirstPrimary(Integer) - Method in class org.apache.flume.channel.SpillableMemoryChannel.DrainOrderQueue
 
putOverflow(Integer) - Method in class org.apache.flume.channel.SpillableMemoryChannel.DrainOrderQueue
 
putPrimary(Integer) - Method in class org.apache.flume.channel.SpillableMemoryChannel.DrainOrderQueue
 
putToFields(String, ByteBuffer) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
putToHeaders(String, String) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 

Q

QUERY_CHANNEL_SIZE - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_INDEX_FLE_CHANNEL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_INDEX_FLH_EVENT - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_INDEX_FLN_HEADER - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_INDEX_FLP_EVENT - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_INDEX_FLV_HEADER - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_SCHEMA_FLUME - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_TABLE_FL_EVENT - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_TABLE_FL_HEADER_FK - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_TABLE_FL_HEADER_FMT - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_TABLE_FL_HEADER_NOFK - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_TABLE_FL_NMSPILL_FK - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_TABLE_FL_NMSPILL_FMT - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_TABLE_FL_NMSPILL_NOFK - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_TABLE_FL_PLSPILL_FK - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_TABLE_FL_PLSPILL_FMT - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_TABLE_FL_PLSPILL_NOFK - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_TABLE_FL_VLSPILL_FK - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_TABLE_FL_VLSPILL_FMT - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_TABLE_FL_VLSPILL_NOFK - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
queue - Variable in class org.apache.flume.channel.SpillableMemoryChannel.DrainOrderQueue
 
QUEUE_SET - Static variable in class org.apache.flume.channel.file.Log
 
QUEUEHEAD_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
queueSize() - Method in class org.apache.flume.channel.SpillableMemoryChannel
 
QUEUESIZE_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 

R

randomKey - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
 
RandomOrderSelector<T> - Class in org.apache.flume.util
An implementation of OrderSelector which returns objects in random order.
RandomOrderSelector(boolean) - Constructor for class org.apache.flume.util.RandomOrderSelector
 
read(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
read(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
 
read(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
 
read(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
 
read() - Method in class org.apache.flume.serialization.ResettableFileInputStream
 
read(byte[], int, int) - Method in class org.apache.flume.serialization.ResettableFileInputStream
 
read() - Method in class org.apache.flume.serialization.ResettableInputStream
Read a single byte of data from the stream.
read(byte[], int, int) - Method in class org.apache.flume.serialization.ResettableInputStream
Read multiple bytes of data from the stream.
read(TProtocol) - Method in class org.apache.flume.source.scribe.LogEntry
 
read(TProtocol) - Method in class org.apache.flume.source.scribe.Scribe.Log_args
 
read(TProtocol) - Method in class org.apache.flume.source.scribe.Scribe.Log_result
 
read(TProtocol) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
read(TProtocol) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
 
read(TProtocol) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
 
read(TProtocol) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
read(TProtocol) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
 
readChar() - Method in class org.apache.flume.serialization.ResettableFileInputStream
 
readChar() - Method in class org.apache.flume.serialization.ResettableInputStream
Read a single character.
readDelimitedBuffer(RandomAccessFile) - Static method in class org.apache.flume.channel.file.LogFile
 
readEvent() - Method in interface org.apache.flume.client.avro.EventReader
Get the next line associated with the input stream.
readEvent() - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader
 
readEvent() - Method in class org.apache.flume.client.avro.SimpleTextLineEventReader
 
readEvent() - Method in class org.apache.flume.serialization.AvroEventDeserializer
 
readEvent() - Method in interface org.apache.flume.serialization.EventDeserializer
Read a single event from the underlying stream.
readEvent() - Method in class org.apache.flume.serialization.LineDeserializer
Reads a line from a file and returns an event
readEvent() - Method in class org.apache.flume.sink.solr.morphline.BlobDeserializer
Reads a BLOB from a file and returns an event
readEvents(int) - Method in interface org.apache.flume.client.avro.EventReader
Get up to n lines associated with the input stream.
readEvents(int) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader
 
readEvents(int) - Method in class org.apache.flume.client.avro.SimpleTextLineEventReader
 
readEvents(int) - Method in class org.apache.flume.serialization.AvroEventDeserializer
 
readEvents(int) - Method in interface org.apache.flume.serialization.EventDeserializer
Read a batch of events from the underlying stream.
readEvents(int) - Method in class org.apache.flume.serialization.LineDeserializer
Batch line read
readEvents(int) - Method in class org.apache.flume.sink.solr.morphline.BlobDeserializer
Batch BLOB read
readFields(DataInput) - Method in class org.apache.flume.channel.file.TransactionEventRecord
 
rebuild() - Method in class org.apache.flume.channel.file.CheckpointRebuilder
 
recv_append() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.Client
 
recv_appendBatch() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.Client
 
recv_close() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
 
recv_Log() - Method in class org.apache.flume.source.scribe.Scribe.Client
 
Recyclable - Annotation Type in org.apache.flume.annotations
 
REGEX - Static variable in class org.apache.flume.interceptor.RegexFilteringInterceptor.Constants
 
REGEX_CONFIG - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
Regular expression used to parse groups from event data.
REGEX_DEFAULT - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
 
RegexExtractorInterceptor - Class in org.apache.flume.interceptor
Interceptor that extracts matches using a specified regular expression and appends the matches to the event headers using the specified serializers
RegexExtractorInterceptor.Builder - Class in org.apache.flume.interceptor
 
RegexExtractorInterceptor.Builder() - Constructor for class org.apache.flume.interceptor.RegexExtractorInterceptor.Builder
 
RegexExtractorInterceptorMillisSerializer - Class in org.apache.flume.interceptor
Serializer that converts the passed in value into milliseconds using the specified formatting pattern
RegexExtractorInterceptorMillisSerializer() - Constructor for class org.apache.flume.interceptor.RegexExtractorInterceptorMillisSerializer
 
RegexExtractorInterceptorPassThroughSerializer - Class in org.apache.flume.interceptor
Serializer that simply returns the passed in value
RegexExtractorInterceptorPassThroughSerializer() - Constructor for class org.apache.flume.interceptor.RegexExtractorInterceptorPassThroughSerializer
 
RegexExtractorInterceptorSerializer - Interface in org.apache.flume.interceptor
Serializer for serializing groups matched by the RegexExtractorInterceptor
RegexFilteringInterceptor - Class in org.apache.flume.interceptor
Interceptor that filters events selectively based on a configured regular expression matching against the event body.
RegexFilteringInterceptor.Builder - Class in org.apache.flume.interceptor
Builder which builds new instance of the StaticInterceptor.
RegexFilteringInterceptor.Builder() - Constructor for class org.apache.flume.interceptor.RegexFilteringInterceptor.Builder
 
RegexFilteringInterceptor.Constants - Class in org.apache.flume.interceptor
 
RegexFilteringInterceptor.Constants() - Constructor for class org.apache.flume.interceptor.RegexFilteringInterceptor.Constants
 
RegexHbaseEventSerializer - Class in org.apache.flume.sink.hbase
An HbaseEventSerializer which parses columns based on a supplied regular expression and column name list.
RegexHbaseEventSerializer() - Constructor for class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.flume.channel.file.proto.ProtosFactory
 
registerCurrentStream(FSDataOutputStream, FileSystem, Path) - Method in class org.apache.flume.sink.hdfs.AbstractHDFSWriter
 
releaseProvider(String) - Static method in class org.apache.flume.channel.jdbc.JdbcChannelProviderFactory
 
ReliableEventReader - Interface in org.apache.flume.client.avro
A reliable event reader.
ReliableSpoolingFileEventReader - Class in org.apache.flume.client.avro

A ReliableEventReader which reads log data from files stored in a spooling directory and renames each file once all of its data has been read (through EventDeserializer.readEvent() calls).

ReliableSpoolingFileEventReader.Builder - Class in org.apache.flume.client.avro
Special builder class for ReliableSpoolingFileEventReader
ReliableSpoolingFileEventReader.Builder() - Constructor for class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
 
RemoteMarkable - Interface in org.apache.flume.serialization
Allows for calling mark() without a seek()
remove() - Method in class org.apache.flume.util.SpecificOrderIterator
 
removeActiveLogs(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
repeated .ActiveLog activeLogs = 5;
removeEvent(String) - Method in class org.apache.flume.channel.jdbc.impl.JdbcChannelProviderImpl
 
removeEvent(String) - Method in interface org.apache.flume.channel.jdbc.JdbcChannelProvider
Removes the next event for the named channel from the underlying persistent store.
removeHeaders(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
repeated .FlumeEventHeader headers = 1;
replaceShorthand(char, Map<String, String>) - Static method in class org.apache.flume.formatter.output.BucketPath
Deprecated.
replaceShorthand(char, Map<String, String>, boolean, int, int) - Static method in class org.apache.flume.formatter.output.BucketPath
Deprecated.
replaceShorthand(char, Map<String, String>, TimeZone, boolean, int, int, boolean) - Static method in class org.apache.flume.formatter.output.BucketPath
Deprecated.
replaceShorthand(char, Map<String, String>, TimeZone, boolean, int, int, boolean, long) - Static method in class org.apache.flume.formatter.output.BucketPath
Not intended as a public API
ReplicatingChannelSelector - Class in org.apache.flume.channel
Replicating channel selector.
ReplicatingChannelSelector() - Constructor for class org.apache.flume.channel.ReplicatingChannelSelector
 
requestTimeout - Variable in class org.apache.flume.api.AbstractRpcClient
 
requiresLayout() - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
 
reset() - Method in class org.apache.flume.serialization.AvroEventDeserializer
 
reset() - Method in interface org.apache.flume.serialization.EventDeserializer
Resets the underlying input stream to the last known mark (or beginning of the stream if EventDeserializer.mark() was never previously called.
reset() - Method in class org.apache.flume.serialization.LineDeserializer
 
reset() - Method in interface org.apache.flume.serialization.Resettable
Return to the last marked position, or the beginning of the stream if Resettable.mark() has never been called.
reset() - Method in class org.apache.flume.serialization.ResettableFileInputStream
 
reset() - Method in class org.apache.flume.serialization.ResettableInputStream
Reset stream position to that set by ResettableInputStream.mark()
reset() - Method in class org.apache.flume.sink.solr.morphline.BlobDeserializer
 
Resettable - Interface in org.apache.flume.serialization
Defines an API for objects that can be mark()ed and reset() on arbitrary boundaries.
ResettableFileInputStream - Class in org.apache.flume.serialization

This class makes the following assumptions: The underlying file is not changing while it is being read

The ability to ResettableFileInputStream.reset() is dependent on the underlying PositionTracker instance's durability semantics.

ResettableFileInputStream(File, PositionTracker) - Constructor for class org.apache.flume.serialization.ResettableFileInputStream
 
ResettableFileInputStream(File, PositionTracker, int, Charset, DecodeErrorPolicy) - Constructor for class org.apache.flume.serialization.ResettableFileInputStream
 
ResettableInputStream - Class in org.apache.flume.serialization
This abstract class defines an interface for which the stream may be marked and reset with no limit to the number of bytes which may have been read between the calls.
ResettableInputStream() - Constructor for class org.apache.flume.serialization.ResettableInputStream
 
RestClient - Static variable in class org.apache.flume.sink.elasticsearch.client.ElasticSearchClientFactory
 
ResultCode - Enum in org.apache.flume.source.scribe
 
rollback() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
rollback() - Method in class org.apache.flume.channel.jdbc.impl.JdbcTransactionImpl
 
rollback() - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel.NoOpTransaction
 
rollback() - Method in interface org.apache.flume.Transaction
Indicates that the transaction can must be aborted.
rollbackTransaction() - Method in interface org.apache.flume.sink.solr.morphline.MorphlineHandler
Performs a rollback of all non-committed documents pending.
rollbackTransaction() - Method in class org.apache.flume.sink.solr.morphline.MorphlineHandlerImpl
 
RollingFileSink - Class in org.apache.flume.sink
 
RollingFileSink() - Constructor for class org.apache.flume.sink.RollingFileSink
 
rotate() - Method in class org.apache.flume.formatter.output.PathManager
 
roundDownTimeStampHours(long, int) - Static method in class org.apache.flume.tools.TimestampRoundDownUtil
 
roundDownTimeStampMinutes(long, int) - Static method in class org.apache.flume.tools.TimestampRoundDownUtil
 
roundDownTimeStampSeconds(long, int) - Static method in class org.apache.flume.tools.TimestampRoundDownUtil
 
RoundRobinList<T> - Class in org.apache.flume.sink.elasticsearch.client
 
RoundRobinList(Collection<T>) - Constructor for class org.apache.flume.sink.elasticsearch.client.RoundRobinList
 
RoundRobinOrderSelector<T> - Class in org.apache.flume.util
An implementation of OrderSelector which returns objects in round robin order.
RoundRobinOrderSelector(boolean) - Constructor for class org.apache.flume.util.RoundRobinOrderSelector
 
ROW_KEY_INDEX_CONFIG - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
Index of the row key in matched regex groups
ROW_KEY_NAME - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
Placeholder in colNames for row key
RpcClient - Interface in org.apache.flume.api
Public client interface for sending data to Flume.
RpcClientConfigurationConstants - Class in org.apache.flume.api
Configuration constants used by the RpcClient.
RpcClientFactory - Class in org.apache.flume.api
Factory class to construct Flume RPCClient implementations.
RpcClientFactory() - Constructor for class org.apache.flume.api.RpcClientFactory
 
RpcClientFactory.ClientType - Enum in org.apache.flume.api
 
run() - Method in class org.apache.flume.instrumentation.GangliaServer.GangliaCollector
 
run() - Method in class org.apache.flume.lifecycle.LifecycleSupervisor.MonitorRunnable
 
run() - Method in class org.apache.flume.node.PollingPropertiesFileConfigurationProvider.FileWatcherRunnable
 
run(String) - Method in interface org.apache.flume.sink.hdfs.HDFSEventSink.WriterCallback
 
run() - Method in class org.apache.flume.SinkRunner.PollingRunner
 
run() - Method in class org.apache.flume.source.PollableSourceRunner.PollingRunner
 
run() - Method in class org.apache.flume.source.thriftLegacy.ThriftLegacySource.ThriftHandler
 
run(String[]) - Method in class org.apache.flume.tools.FileChannelIntegrityTool
 
run(String[]) - Method in interface org.apache.flume.tools.FlumeTool
 
run(String[]) - Method in class org.apache.flume.tools.FlumeToolsMain
 

S

schemaExists() - Method in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
schemaExists() - Method in class org.apache.flume.channel.jdbc.impl.MySQLSchemaHandler
 
schemaExists() - Method in interface org.apache.flume.channel.jdbc.impl.SchemaHandler
 
SchemaHandler - Interface in org.apache.flume.channel.jdbc.impl
A handler for creating and validating database schema for use by the JDBC channel implementation.
SchemaHandlerFactory - Class in org.apache.flume.channel.jdbc.impl
A factory for SchemaHandlers.
Scribe - Class in org.apache.flume.source.scribe
 
Scribe() - Constructor for class org.apache.flume.source.scribe.Scribe
 
Scribe.AsyncClient - Class in org.apache.flume.source.scribe
 
Scribe.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.flume.source.scribe.Scribe.AsyncClient
 
Scribe.AsyncClient.Factory - Class in org.apache.flume.source.scribe
 
Scribe.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.flume.source.scribe.Scribe.AsyncClient.Factory
 
Scribe.AsyncClient.Log_call - Class in org.apache.flume.source.scribe
 
Scribe.AsyncClient.Log_call(List<LogEntry>, AsyncMethodCallback<Scribe.AsyncClient.Log_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.flume.source.scribe.Scribe.AsyncClient.Log_call
 
Scribe.AsyncIface - Interface in org.apache.flume.source.scribe
 
Scribe.Client - Class in org.apache.flume.source.scribe
 
Scribe.Client(TProtocol) - Constructor for class org.apache.flume.source.scribe.Scribe.Client
 
Scribe.Client(TProtocol, TProtocol) - Constructor for class org.apache.flume.source.scribe.Scribe.Client
 
Scribe.Client.Factory - Class in org.apache.flume.source.scribe
 
Scribe.Client.Factory() - Constructor for class org.apache.flume.source.scribe.Scribe.Client.Factory
 
Scribe.Iface - Interface in org.apache.flume.source.scribe
 
Scribe.Log_args - Class in org.apache.flume.source.scribe
 
Scribe.Log_args() - Constructor for class org.apache.flume.source.scribe.Scribe.Log_args
 
Scribe.Log_args(List<LogEntry>) - Constructor for class org.apache.flume.source.scribe.Scribe.Log_args
 
Scribe.Log_args(Scribe.Log_args) - Constructor for class org.apache.flume.source.scribe.Scribe.Log_args
Performs a deep copy on other.
Scribe.Log_args._Fields - Enum in org.apache.flume.source.scribe
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Scribe.Log_result - Class in org.apache.flume.source.scribe
 
Scribe.Log_result() - Constructor for class org.apache.flume.source.scribe.Scribe.Log_result
 
Scribe.Log_result(ResultCode) - Constructor for class org.apache.flume.source.scribe.Scribe.Log_result
 
Scribe.Log_result(Scribe.Log_result) - Constructor for class org.apache.flume.source.scribe.Scribe.Log_result
Performs a deep copy on other.
Scribe.Log_result._Fields - Enum in org.apache.flume.source.scribe
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Scribe.Processor<I extends Scribe.Iface> - Class in org.apache.flume.source.scribe
 
Scribe.Processor(I) - Constructor for class org.apache.flume.source.scribe.Scribe.Processor
 
Scribe.Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.flume.source.scribe.Scribe.Processor
 
SCRIBE_CATEGORY - Static variable in class org.apache.flume.source.scribe.ScribeSource
 
ScribeSource - Class in org.apache.flume.source.scribe
Flume should adopt the Scribe entry LogEntry from existing Scribe system.
ScribeSource() - Constructor for class org.apache.flume.source.scribe.ScribeSource
 
seek(long) - Method in class org.apache.flume.serialization.ResettableFileInputStream
 
seek(long) - Method in class org.apache.flume.serialization.ResettableInputStream
Seek to the specified byte position in the stream.
seek(long) - Method in interface org.apache.flume.serialization.Seekable
 
Seekable - Interface in org.apache.flume.serialization
 
SELECTOR_NAME_RANDOM - Static variable in class org.apache.flume.sink.LoadBalancingSinkProcessor
 
SELECTOR_NAME_RANDOM_BACKOFF - Static variable in class org.apache.flume.sink.LoadBalancingSinkProcessor
 
SELECTOR_NAME_ROUND_ROBIN - Static variable in class org.apache.flume.sink.LoadBalancingSinkProcessor
 
SELECTOR_NAME_ROUND_ROBIN_BACKOFF - Static variable in class org.apache.flume.sink.LoadBalancingSinkProcessor
 
selectorConf - Variable in class org.apache.flume.conf.source.SourceConfiguration
 
send_append(ThriftFlumeEvent) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
 
send_append(ThriftFlumeEvent) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.Client
 
send_appendBatch(List<ThriftFlumeEvent>) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.Client
 
send_close() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
 
send_Log(List<LogEntry>) - Method in class org.apache.flume.source.scribe.Scribe.Client
 
sendToGangliaNodes() - Method in class org.apache.flume.instrumentation.GangliaServer
 
SEPERATOR - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
 
SequenceFileSerializer - Interface in org.apache.flume.sink.hdfs
 
SequenceFileSerializer.Builder - Interface in org.apache.flume.sink.hdfs
Knows how to construct this output formatter.
Note: Implementations MUST provide a public a no-arg constructor.
SequenceFileSerializer.Record - Class in org.apache.flume.sink.hdfs
A key-value pair making up a record in an HDFS SequenceFile
SequenceFileSerializer.Record(Object, Object) - Constructor for class org.apache.flume.sink.hdfs.SequenceFileSerializer.Record
 
SequenceFileSerializerFactory - Class in org.apache.flume.sink.hdfs
 
SequenceFileSerializerFactory() - Constructor for class org.apache.flume.sink.hdfs.SequenceFileSerializerFactory
 
SequenceFileSerializerType - Enum in org.apache.flume.sink.hdfs
 
SequenceGeneratorSource - Class in org.apache.flume.source
 
SequenceGeneratorSource() - Constructor for class org.apache.flume.source.SequenceGeneratorSource
 
Serialization - Class in org.apache.flume.channel.file
 
serialize(String) - Method in class org.apache.flume.interceptor.RegexExtractorInterceptorMillisSerializer
 
serialize(String) - Method in class org.apache.flume.interceptor.RegexExtractorInterceptorPassThroughSerializer
 
serialize(String) - Method in interface org.apache.flume.interceptor.RegexExtractorInterceptorSerializer
 
serialize(Event) - Method in class org.apache.flume.sink.hdfs.HDFSTextSerializer
 
serialize(Event) - Method in class org.apache.flume.sink.hdfs.HDFSWritableSerializer
 
serialize(Event) - Method in interface org.apache.flume.sink.hdfs.SequenceFileSerializer
Format the given event into zero, one or more SequenceFile records
SERIALIZER - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
The fully qualified class name of the serializer the sink should use.
serializer - Variable in class org.apache.flume.sink.elasticsearch.EventSerializerIndexRequestBuilderFactory
 
SERIALIZER_PREFIX - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
Configuration to pass to the serializer.
set(String, Long) - Method in class org.apache.flume.CounterGroup
 
set(String, long) - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
Sets the value for this key to the given value
setActiveLogs(int, ProtosFactory.ActiveLog) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
repeated .ActiveLog activeLogs = 5;
setActiveLogs(int, ProtosFactory.ActiveLog.Builder) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
repeated .ActiveLog activeLogs = 5;
setAvroReflectionEnabled(boolean) - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
 
setAvroSchemaUrl(String) - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
 
setBackOff(boolean) - Method in class org.apache.flume.source.SpoolDirectorySource
The class always backs off, this exists only so that we can test without taking a really long time.
setBackupCheckpointPosition(long) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
optional sfixed64 backupCheckpointPosition = 6;
setBackupCheckpointWriteOrderID(long) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
optional sfixed64 backupCheckpointWriteOrderID = 7;
setBaseDirectory(File) - Method in class org.apache.flume.formatter.output.PathManager
 
setBasePayload(byte[]) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
 
setBody(byte[]) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
setBody(ByteBuffer) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
setBody(ByteString) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
required bytes body = 2;
setBody(byte[]) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
setBody(byte[]) - Method in class org.apache.flume.event.JSONEvent
 
setBody(byte[]) - Method in interface org.apache.flume.Event
Sets the raw byte array of the data contained in this event.
setBody(byte[]) - Method in class org.apache.flume.event.SimpleEvent
 
setBody(byte[]) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
setBody(ByteBuffer) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
setBodyIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
setBodyIsSet(boolean) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
setCategory(String) - Method in class org.apache.flume.source.scribe.LogEntry
 
setCategoryIsSet(boolean) - Method in class org.apache.flume.source.scribe.LogEntry
 
setChannel(String) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
 
setChannel(Channel) - Method in class org.apache.flume.sink.AbstractSink
 
setChannel(Channel) - Method in interface org.apache.flume.Sink
Sets the channel the sink will consume from
setChannelCapacity(long) - Method in class org.apache.flume.instrumentation.ChannelCounter
 
setChannelProcessor(ChannelProcessor) - Method in class org.apache.flume.source.AbstractSource
 
setChannelProcessor(ChannelProcessor) - Method in class org.apache.flume.source.BasicSourceSemantics
 
setChannelProcessor(ChannelProcessor) - Method in interface org.apache.flume.Source
Specifies which channel processor will handle this source's events.
setChannels(List<Channel>) - Method in class org.apache.flume.channel.AbstractChannelSelector
 
setChannels(List<Channel>) - Method in interface org.apache.flume.ChannelSelector
 
setChannels(Set<String>) - Method in class org.apache.flume.conf.channel.ChannelSelectorConfiguration
 
setChannelSize(long) - Method in class org.apache.flume.instrumentation.ChannelCounter
 
setCharset(String) - Method in class org.apache.flume.event.JSONEvent
 
setCheckpointPosition(long) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
required sfixed64 checkpointPosition = 3;
setCheckpointWriteOrderID(long) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
required sfixed64 checkpointWriteOrderID = 4;
setChecksum(long) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
optional sfixed64 checksum = 2;
setCipherProvider(String) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
required string cipherProvider = 1;
setCipherProviderBytes(ByteString) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
required string cipherProvider = 1;
setClock(Clock) - Static method in class org.apache.flume.formatter.output.BucketPath
 
setConfigured() - Method in class org.apache.flume.conf.ComponentConfiguration
 
setCount(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
required sfixed32 count = 2;
setCounters(HashMap<String, AtomicLong>) - Method in class org.apache.flume.CounterGroup
 
setDesiredState(LifecycleAware, LifecycleState) - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
 
setDirectory(File) - Method in class org.apache.flume.sink.RollingFileSink
 
setEncryption(ProtosFactory.LogFileEncryption) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
optional .LogFileEncryption encryption = 5;
setEncryption(ProtosFactory.LogFileEncryption.Builder) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
optional .LogFileEncryption encryption = 5;
setEvent(ProtosFactory.FlumeEvent) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
required .FlumeEvent event = 1;
setEvent(ProtosFactory.FlumeEvent.Builder) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put.Builder
required .FlumeEvent event = 1;
setEvent(Event) - Method in interface org.apache.flume.sink.hbase.AsyncHbaseEventSerializer
 
setEvent(Event) - Method in class org.apache.flume.sink.hbase.SimpleAsyncHbaseEventSerializer
 
setEvent(ThriftFlumeEvent) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
 
setEventId(long) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
 
setEventId(long) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
setEventIsSet(boolean) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
 
setEvents(List<ThriftFlumeEvent>) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
setEventsIsSet(boolean) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
setEventSize(int) - Method in class org.apache.flume.source.SyslogTcpSource.syslogTcpHandler
 
setEventSize(Integer) - Method in class org.apache.flume.source.SyslogUtils
 
setEvt(ThriftFlumeEvent) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
 
setEvtIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
 
setFields(Map<String, ByteBuffer>) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
setFieldsIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
setFieldValue(ThriftFlumeEvent._Fields, Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
setFieldValue(ThriftFlumeEventServer.append_args._Fields, Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
 
setFieldValue(ThriftFlumeEventServer.close_args._Fields, Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
 
setFieldValue(ThriftFlumeEventServer.close_result._Fields, Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
 
setFieldValue(LogEntry._Fields, Object) - Method in class org.apache.flume.source.scribe.LogEntry
 
setFieldValue(Scribe.Log_args._Fields, Object) - Method in class org.apache.flume.source.scribe.Scribe.Log_args
 
setFieldValue(Scribe.Log_result._Fields, Object) - Method in class org.apache.flume.source.scribe.Scribe.Log_result
 
setFieldValue(ThriftFlumeEvent._Fields, Object) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
setFieldValue(ThriftSourceProtocol.append_args._Fields, Object) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
 
setFieldValue(ThriftSourceProtocol.append_result._Fields, Object) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
 
setFieldValue(ThriftSourceProtocol.appendBatch_args._Fields, Object) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
setFieldValue(ThriftSourceProtocol.appendBatch_result._Fields, Object) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
 
setFileID(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
required sfixed32 fileID = 1;
setFormater(Map<String, String>) - Method in class org.apache.flume.source.SyslogTcpSource.syslogTcpHandler
 
setFormater(Map<String, String>) - Method in class org.apache.flume.source.SyslogUDPSource.syslogHandler
 
setHeader(long, String, String) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
 
setHeaderNameSpill(long, String) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
 
setHeaders(int, ProtosFactory.FlumeEventHeader) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
repeated .FlumeEventHeader headers = 1;
setHeaders(int, ProtosFactory.FlumeEventHeader.Builder) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent.Builder
repeated .FlumeEventHeader headers = 1;
setHeaders(Map<String, String>) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
setHeaders(Map<String, String>) - Method in class org.apache.flume.event.JSONEvent
 
setHeaders(Map<String, String>) - Method in interface org.apache.flume.Event
Set the event headers
setHeaders(Map<String, String>) - Method in class org.apache.flume.event.SimpleEvent
 
setHeaders(Map<String, String>) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
setHeadersIsSet(boolean) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
setHeaderValueSpill(long, String) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
 
setHost(String) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
setHostIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
setHostname(String) - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
Set the first flume hop hostname.
setHosts(List<HostInfo>) - Method in interface org.apache.flume.api.LoadBalancingRpcClient.HostSelector
 
setHosts(String) - Method in class org.apache.flume.clients.log4jappender.LoadBalancingLog4jAppender
 
setId(long) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
 
setInterceptors(List<Interceptor>) - Method in class org.apache.flume.interceptor.InterceptorChain
 
setIsGanglia3(boolean) - Method in class org.apache.flume.instrumentation.GangliaServer
 
setKeepFields(boolean) - Method in class org.apache.flume.source.SyslogTcpSource.syslogTcpHandler
 
setKeepFields(boolean) - Method in class org.apache.flume.source.SyslogUDPSource.syslogHandler
 
setKeepFields(Boolean) - Method in class org.apache.flume.source.SyslogUtils
 
setKey(Key) - Method in class org.apache.flume.channel.file.encryption.CipherProvider.Decryptor.Builder
 
setKey(Key) - Method in class org.apache.flume.channel.file.encryption.CipherProvider.Encryptor.Builder
 
setKey(String) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
required string key = 1;
setKeyAlias(String) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
required string keyAlias = 2;
setKeyAliasBytes(ByteString) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
required string keyAlias = 2;
setKeyBytes(ByteString) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
required string key = 1;
setLastCheckpointPosition(long) - Method in class org.apache.flume.channel.file.LogFile.SequentialReader
 
setLastCheckpointWriteOrderID(long) - Method in class org.apache.flume.channel.file.LogFile.SequentialReader
 
setLifecycleState(LifecycleState) - Method in class org.apache.flume.source.BasicSourceSemantics
 
setLogFileID(int) - Method in class org.apache.flume.channel.file.LogFile.SequentialReader
 
setLogFileID(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog.Builder
required sfixed32 logFileID = 1;
setLogFileID(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
required sfixed32 logFileID = 2;
setMaxBackoff(String) - Method in class org.apache.flume.clients.log4jappender.LoadBalancingLog4jAppender
 
setMaxTimeOut(long) - Method in class org.apache.flume.util.OrderSelector
 
setMessage(String) - Method in class org.apache.flume.source.scribe.LogEntry
 
setMessageIsSet(boolean) - Method in class org.apache.flume.source.scribe.LogEntry
 
setMessages(List<LogEntry>) - Method in class org.apache.flume.source.scribe.Scribe.Log_args
 
setMessagesIsSet(boolean) - Method in class org.apache.flume.source.scribe.Scribe.Log_args
 
setName(String) - Method in class org.apache.flume.channel.AbstractChannel
 
setName(String) - Method in class org.apache.flume.channel.AbstractChannelSelector
 
setName(String) - Method in class org.apache.flume.channel.file.FileChannel
 
setName(String) - Method in class org.apache.flume.CounterGroup
 
setName(String) - Method in interface org.apache.flume.NamedComponent
 
setName(String) - Method in class org.apache.flume.sink.AbstractSink
 
setName(String) - Method in class org.apache.flume.source.AbstractSource
 
setName(String) - Method in class org.apache.flume.source.BasicSourceSemantics
 
setNanos(long) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
setNanosIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
setNotFoundConfigClass() - Method in class org.apache.flume.conf.ComponentConfiguration
 
setObjects(List<T>) - Method in class org.apache.flume.util.OrderSelector
Set the list of objects which this class should return in order.
setOffset(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take.Builder
required sfixed32 offset = 2;
setOpenConnectionCount(long) - Method in class org.apache.flume.instrumentation.SourceCounter
 
setParameters(byte[]) - Method in class org.apache.flume.channel.file.encryption.CipherProvider.Decryptor.Builder
 
setParameters(ByteString) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption.Builder
optional bytes parameters = 3;
setPollFrequency(int) - Method in class org.apache.flume.instrumentation.GangliaServer
 
setPort(int) - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
Set the port on the hostname to connect to.
setPreviousCheckpointPosition(long) - Method in class org.apache.flume.channel.file.LogFile.SequentialReader
 
setPreviousCheckpointWriteOrderID(long) - Method in class org.apache.flume.channel.file.LogFile.SequentialReader
 
setPriority(Priority) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
setPriorityIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
setProcessorContext(Context) - Method in class org.apache.flume.conf.sink.SinkGroupConfiguration
 
setQueueHead(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
required sfixed32 queueHead = 4;
setQueueSize(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
required sfixed32 queueSize = 3;
setRollInterval(long) - Method in class org.apache.flume.sink.RollingFileSink
 
setSeed(long) - Static method in class org.apache.flume.channel.file.TransactionIDOracle
 
setSeed(long) - Static method in class org.apache.flume.channel.file.WriteOrderOracle
 
setSelector(String) - Method in class org.apache.flume.clients.log4jappender.LoadBalancingLog4jAppender
 
setSink(SinkProcessor) - Method in class org.apache.flume.SinkRunner
 
setSinkProcessorConfiguration(SinkProcessorConfiguration) - Method in class org.apache.flume.conf.sink.SinkGroupConfiguration
 
setSinks(List<String>) - Method in class org.apache.flume.conf.sink.SinkGroupConfiguration
 
setSinks(Set<String>) - Method in class org.apache.flume.conf.sink.SinkProcessorConfiguration
 
setSinks(List<Sink>) - Method in class org.apache.flume.sink.AbstractSinkProcessor
 
setSinks(List<Sink>) - Method in class org.apache.flume.sink.AbstractSinkSelector
 
setSinks(List<Sink>) - Method in class org.apache.flume.sink.DefaultSinkProcessor
 
setSinks(List<Sink>) - Method in class org.apache.flume.sink.FailoverSinkProcessor
 
setSinks(List<Sink>) - Method in interface org.apache.flume.sink.LoadBalancingSinkProcessor.SinkSelector
 
setSinks(List<Sink>) - Method in interface org.apache.flume.SinkProcessor
Set all sinks to work with.
setSource(Source) - Method in class org.apache.flume.SourceRunner
 
setSpillPayload(byte[]) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
 
setSuccess(ResultCode) - Method in class org.apache.flume.source.scribe.Scribe.Log_result
 
setSuccess(Status) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
 
setSuccess(Status) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
 
setSuccessIsSet(boolean) - Method in class org.apache.flume.source.scribe.Scribe.Log_result
 
setSuccessIsSet(boolean) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
 
setSuccessIsSet(boolean) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
 
setTimeout(long) - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
 
setTimestamp(long) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
setTimestampIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
setTransactionID(long) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
required sfixed64 transactionID = 2;
setType(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit.Builder
required sfixed32 type = 1;
setType(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
required sfixed32 type = 1;
setType(String) - Method in class org.apache.flume.conf.ComponentConfiguration
 
setUnsafeMode(boolean) - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
 
setValue(String) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
required string value = 2;
setValueBytes(ByteString) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader.Builder
required string value = 2;
setVersion(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
required sfixed32 version = 1;
setVersion(int) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData.Builder
required sfixed32 version = 1;
setWriteOrderID(long) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint.Builder
required sfixed64 writeOrderID = 2;
setWriteOrderID(long) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader.Builder
required sfixed64 writeOrderID = 3;
sharedInstance() - Static method in class org.apache.flume.channel.PseudoTxnMemoryChannel.NoOpTransaction
 
SimpleAsyncHbaseEventSerializer - Class in org.apache.flume.sink.hbase
A simple serializer to be used with the AsyncHBaseSink that returns puts from an event, by writing the event body into it.
SimpleAsyncHbaseEventSerializer() - Constructor for class org.apache.flume.sink.hbase.SimpleAsyncHbaseEventSerializer
 
SimpleEvent - Class in org.apache.flume.event
 
SimpleEvent() - Constructor for class org.apache.flume.event.SimpleEvent
 
SimpleHbaseEventSerializer - Class in org.apache.flume.sink.hbase
A simple serializer that returns puts from an event, by writing the event body into it.
SimpleHbaseEventSerializer() - Constructor for class org.apache.flume.sink.hbase.SimpleHbaseEventSerializer
 
SimpleHbaseEventSerializer.KeyType - Enum in org.apache.flume.sink.hbase
 
SimpleIndexNameBuilder - Class in org.apache.flume.sink.elasticsearch
 
SimpleIndexNameBuilder() - Constructor for class org.apache.flume.sink.elasticsearch.SimpleIndexNameBuilder
 
SimpleMaterializedConfiguration - Class in org.apache.flume.node
 
SimpleMaterializedConfiguration() - Constructor for class org.apache.flume.node.SimpleMaterializedConfiguration
 
SimpleRowKeyGenerator - Class in org.apache.flume.sink.hbase
Utility class for users to generate their own keys.
SimpleRowKeyGenerator() - Constructor for class org.apache.flume.sink.hbase.SimpleRowKeyGenerator
 
SimpleTextLineEventReader - Class in org.apache.flume.client.avro
A EventReader implementation which delegates to a BufferedReader.
SimpleTextLineEventReader(Reader) - Constructor for class org.apache.flume.client.avro.SimpleTextLineEventReader
 
Sink - Interface in org.apache.flume
A sink is connected to a Channel and consumes its contents, sending them to a configured destination that may vary according to the sink type.
Sink.Status - Enum in org.apache.flume
 
SINK_PROCESSOR - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
Prefix for sink processor properties
SINK_PROCESSOR_PREFIX - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
Prefix for passing configuration parameters to the sink processor
SINK_PROCESSOR_TYPE - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
Sink processor type, choices are `default', `failover' or `load_balance'
SINK_PROCESSOR_TYPE_DEFAULT - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
Default sink processors which may be used when there is only a single sink.
SINK_PROCESSOR_TYPE_FAILOVER - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
Failover sink processor.
SINK_PROCESSOR_TYPE_LOAD_BALANCE - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
Load balancing sink processor.
SINK_TYPE_AVRO - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
Avro sink which can send events to a downstream avro source.
SinkConfiguration - Class in org.apache.flume.conf.sink
 
SinkConfiguration(String) - Constructor for class org.apache.flume.conf.sink.SinkConfiguration
 
SinkConfiguration.SinkConfigurationType - Enum in org.apache.flume.conf.sink
 
SinkCounter - Class in org.apache.flume.instrumentation
 
SinkCounter(String) - Constructor for class org.apache.flume.instrumentation.SinkCounter
 
SinkCounterMBean - Interface in org.apache.flume.instrumentation
This interface represents a sink counter mbean.
SinkFactory - Interface in org.apache.flume
 
SinkGroup - Class in org.apache.flume.sink
Configuration concept for handling multiple sinks working together.
SinkGroup(List<Sink>) - Constructor for class org.apache.flume.sink.SinkGroup
 
SinkGroupConfiguration - Class in org.apache.flume.conf.sink
 
SinkGroupConfiguration(String) - Constructor for class org.apache.flume.conf.sink.SinkGroupConfiguration
 
SinkProcessor - Interface in org.apache.flume
Interface for a device that allows abstraction of the behavior of multiple sinks, always assigned to a SinkRunner
SinkProcessorConfiguration - Class in org.apache.flume.conf.sink
 
SinkProcessorConfiguration(String) - Constructor for class org.apache.flume.conf.sink.SinkProcessorConfiguration
 
SinkProcessorConfiguration.SinkProcessorConfigurationType - Enum in org.apache.flume.conf.sink
 
SinkProcessorCounter - Class in org.apache.flume.instrumentation
 
SinkProcessorCounter(String) - Constructor for class org.apache.flume.instrumentation.SinkProcessorCounter
 
SinkProcessorFactory - Class in org.apache.flume.sink
 
SinkProcessorFactory() - Constructor for class org.apache.flume.sink.SinkProcessorFactory
 
SinkProcessorType - Enum in org.apache.flume.conf.sink
 
SinkRunner - Class in org.apache.flume
A driver for sinks that polls them, attempting to process events if any are available in the Channel.
SinkRunner() - Constructor for class org.apache.flume.SinkRunner
 
SinkRunner(SinkProcessor) - Constructor for class org.apache.flume.SinkRunner
 
SinkRunner.PollingRunner - Class in org.apache.flume
Runnable that polls a SinkProcessor and manages event delivery notification, BACKOFF delay handling, etc.
SinkRunner.PollingRunner() - Constructor for class org.apache.flume.SinkRunner.PollingRunner
 
SINKS - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
Space delimited list of sink names: e.g.
sinks - Variable in class org.apache.flume.conf.sink.SinkProcessorConfiguration
 
SINKS_PREFIX - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
 
SinkType - Enum in org.apache.flume.conf.sink
Enumeration of built in sink types available in the system.
size() - Method in class org.apache.flume.sink.elasticsearch.client.RoundRobinList
 
skipRecord(RandomAccessFile, int) - Static method in class org.apache.flume.channel.file.LogFile
 
SOURCE - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
Prefix for source properties
Source - Interface in org.apache.flume
A source generates and calls methods on the configured ChannelProcessor to persist those events into the configured channels.
SOURCE_PREFIX - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
Prefix for passing configuration parameters to the source
SOURCE_TYPE - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
Source type, choices are `embedded'
SOURCE_TYPE_EMBEDDED - Static variable in class org.apache.flume.agent.embedded.EmbeddedAgentConfiguration
Embedded source which provides simple in-memory transfer to channel.
SourceConfiguration - Class in org.apache.flume.conf.source
 
SourceConfiguration(String) - Constructor for class org.apache.flume.conf.source.SourceConfiguration
 
SourceConfiguration.SourceConfigurationType - Enum in org.apache.flume.conf.source
 
SourceCounter - Class in org.apache.flume.instrumentation
 
SourceCounter(String) - Constructor for class org.apache.flume.instrumentation.SourceCounter
 
SourceCounterMBean - Interface in org.apache.flume.instrumentation
This interface represents a source counter mbean.
SourceFactory - Interface in org.apache.flume
 
SourceRunner - Class in org.apache.flume
A source runner controls how a source is driven.
SourceRunner() - Constructor for class org.apache.flume.SourceRunner
 
SourceType - Enum in org.apache.flume.conf.source
Enumeration of built in source types available in the system.
SpecificOrderIterator<T> - Class in org.apache.flume.util
A utility class that iterates over the given ordered list of items via the specified order array.
SpecificOrderIterator(int[], List<T>) - Constructor for class org.apache.flume.util.SpecificOrderIterator
 
SpillableMemoryChannel - Class in org.apache.flume.channel
SpillableMemoryChannel will use main memory for buffering events until it has reached capacity.
SpillableMemoryChannel() - Constructor for class org.apache.flume.channel.SpillableMemoryChannel
 
SpillableMemoryChannel.DrainOrderQueue - Class in org.apache.flume.channel
 
SpillableMemoryChannel.DrainOrderQueue() - Constructor for class org.apache.flume.channel.SpillableMemoryChannel.DrainOrderQueue
 
SPOOL_DIRECTORY - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
Directory where files are deposited.
spoolDirectory(File) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
 
SpoolDirectorySource - Class in org.apache.flume.source
 
SpoolDirectorySource() - Constructor for class org.apache.flume.source.SpoolDirectorySource
 
SpoolDirectorySourceConfigurationConstants - Class in org.apache.flume.source
 
SpoolDirectorySourceConfigurationConstants() - Constructor for class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
 
SpoolDirectorySourceConfigurationConstants.ConsumeOrder - Enum in org.apache.flume.source
Consume order.
SPOOLED_FILE_SUFFIX - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
Suffix appended to files when they are finished being sent.
SSL_ENABLED - Static variable in class org.apache.flume.source.http.HTTPSourceConfigurationConstants
 
SSL_KEYSTORE - Static variable in class org.apache.flume.source.http.HTTPSourceConfigurationConstants
 
SSL_KEYSTORE_PASSWORD - Static variable in class org.apache.flume.source.http.HTTPSourceConfigurationConstants
 
start() - Method in class org.apache.flume.agent.embedded.EmbeddedAgent
Started the agent.
start() - Method in class org.apache.flume.channel.AbstractChannel
 
start() - Method in class org.apache.flume.channel.file.FileChannel
 
start() - Method in class org.apache.flume.channel.MemoryChannel
 
start() - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel
 
start() - Method in class org.apache.flume.channel.SpillableMemoryChannel
 
start() - Method in class org.apache.flume.instrumentation.GangliaServer
Start this server, causing it to poll JMX at the configured frequency.
start() - Method in class org.apache.flume.instrumentation.http.HTTPMetricsServer
 
start() - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
Starts the component Initializes the values for the stop time as well as all the keys in the internal map to zero and sets the start time to the current time in milliseconds since midnight January 1, 1970 UTC
start() - Method in interface org.apache.flume.instrumentation.MonitorService
 
start() - Method in interface org.apache.flume.lifecycle.LifecycleAware
Starts a service or component.
start() - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
 
start() - Method in class org.apache.flume.node.Application
 
start() - Method in class org.apache.flume.node.PollingPropertiesFileConfigurationProvider
 
start() - Method in class org.apache.flume.sink.AbstractRpcSink
The start() of RpcSink is more of an optimization that allows connection to be created before the process() loop is started.
start() - Method in class org.apache.flume.sink.AbstractSink
 
start() - Method in class org.apache.flume.sink.AbstractSinkProcessor
 
start() - Method in class org.apache.flume.sink.AbstractSinkSelector
 
start() - Method in class org.apache.flume.sink.DefaultSinkProcessor
 
start() - Method in class org.apache.flume.sink.elasticsearch.ElasticSearchSink
 
start() - Method in class org.apache.flume.sink.hbase.AsyncHBaseSink
 
start() - Method in class org.apache.flume.sink.hbase.HBaseSink
 
start() - Method in class org.apache.flume.sink.hdfs.HDFSEventSink
 
start() - Method in class org.apache.flume.sink.irc.IRCSink
 
start() - Method in class org.apache.flume.sink.LoadBalancingSinkProcessor
 
start() - Method in class org.apache.flume.sink.NullSink
 
start() - Method in class org.apache.flume.sink.RollingFileSink
 
start() - Method in class org.apache.flume.sink.solr.morphline.MorphlineSink
 
start() - Method in class org.apache.flume.SinkRunner
 
start() - Method in class org.apache.flume.source.AbstractSource
 
start() - Method in class org.apache.flume.source.avroLegacy.AvroLegacySource
 
start() - Method in class org.apache.flume.source.AvroSource
 
start() - Method in class org.apache.flume.source.BasicSourceSemantics
 
start() - Method in class org.apache.flume.source.EventDrivenSourceRunner
 
start() - Method in class org.apache.flume.source.ExecSource
 
start() - Method in class org.apache.flume.source.http.HTTPSource
 
start() - Method in class org.apache.flume.source.MultiportSyslogTCPSource
 
start() - Method in class org.apache.flume.source.NetcatSource
 
start() - Method in class org.apache.flume.source.PollableSourceRunner
 
start() - Method in class org.apache.flume.source.scribe.ScribeSource
 
start() - Method in class org.apache.flume.source.SequenceGeneratorSource
 
start() - Method in class org.apache.flume.source.SpoolDirectorySource
 
start() - Method in class org.apache.flume.source.StressSource
 
start() - Method in class org.apache.flume.source.SyslogTcpSource
 
start() - Method in class org.apache.flume.source.SyslogUDPSource
 
start() - Method in class org.apache.flume.source.thriftLegacy.ThriftLegacySource
 
start() - Method in class org.apache.flume.source.ThriftSource
 
start() - Method in class org.apache.flume.source.twitter.TwitterSource
 
START_OR_ERROR - Static variable in enum org.apache.flume.lifecycle.LifecycleState
 
StaticInterceptor - Class in org.apache.flume.interceptor
Interceptor class that appends a static, pre-configured header to all events.
StaticInterceptor.Builder - Class in org.apache.flume.interceptor
Builder which builds new instance of the StaticInterceptor.
StaticInterceptor.Builder() - Constructor for class org.apache.flume.interceptor.StaticInterceptor.Builder
 
StaticInterceptor.Constants - Class in org.apache.flume.interceptor
 
StaticInterceptor.Constants() - Constructor for class org.apache.flume.interceptor.StaticInterceptor.Constants
 
Status - Enum in org.apache.flume.thrift
 
STMT_DELETE_EVENT_BASE - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_DELETE_EVENT_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_DELETE_HEADER_BASE - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_DELETE_HEADER_NAME_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_DELETE_HEADER_VALUE_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_FETCH_HEADER_BASE - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_FETCH_HEADER_NAME_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_FETCH_HEADER_VALUE_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_FETCH_PAYLOAD_BASE - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_FETCH_PAYLOAD_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_INSERT_EVENT_BASE - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_INSERT_EVENT_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_INSERT_HEADER_BASE - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_INSERT_HEADER_NAME_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_INSERT_HEADER_VALUE_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
stop() - Method in class org.apache.flume.agent.embedded.EmbeddedAgent
Stops the agent.
stop() - Method in class org.apache.flume.channel.AbstractChannel
 
stop() - Method in class org.apache.flume.channel.file.FileChannel
 
stop() - Method in class org.apache.flume.channel.jdbc.JdbcChannel
 
stop() - Method in class org.apache.flume.channel.MemoryChannel
 
stop() - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel
 
stop() - Method in class org.apache.flume.channel.SpillableMemoryChannel
 
stop() - Method in class org.apache.flume.instrumentation.GangliaServer
Stop this server.
stop() - Method in class org.apache.flume.instrumentation.http.HTTPMetricsServer
 
stop() - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
Shuts Down the Component Used to indicate that the component is shutting down.
stop() - Method in interface org.apache.flume.instrumentation.MonitorService
 
stop() - Method in interface org.apache.flume.lifecycle.LifecycleAware
Stops a service or component.
stop() - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
 
stop() - Method in class org.apache.flume.node.Application
 
stop() - Method in class org.apache.flume.node.PollingPropertiesFileConfigurationProvider
 
stop() - Method in class org.apache.flume.sink.AbstractRpcSink
 
stop() - Method in class org.apache.flume.sink.AbstractSink
 
stop() - Method in class org.apache.flume.sink.AbstractSinkProcessor
 
stop() - Method in class org.apache.flume.sink.AbstractSinkSelector
 
stop() - Method in class org.apache.flume.sink.DefaultSinkProcessor
 
stop() - Method in class org.apache.flume.sink.elasticsearch.ElasticSearchSink
 
stop() - Method in class org.apache.flume.sink.hbase.AsyncHBaseSink
 
stop() - Method in class org.apache.flume.sink.hbase.HBaseSink
 
stop() - Method in class org.apache.flume.sink.hdfs.HDFSEventSink
 
stop() - Method in class org.apache.flume.sink.irc.IRCSink
 
stop() - Method in class org.apache.flume.sink.LoadBalancingSinkProcessor
 
stop() - Method in class org.apache.flume.sink.NullSink
 
stop() - Method in class org.apache.flume.sink.RollingFileSink
 
stop() - Method in interface org.apache.flume.sink.solr.morphline.MorphlineHandler
Releases allocated resources
stop() - Method in class org.apache.flume.sink.solr.morphline.MorphlineHandlerImpl
 
stop() - Method in class org.apache.flume.sink.solr.morphline.MorphlineSink
 
stop() - Method in class org.apache.flume.SinkRunner
 
stop() - Method in class org.apache.flume.source.AbstractSource
 
stop() - Method in class org.apache.flume.source.avroLegacy.AvroLegacySource
 
stop() - Method in class org.apache.flume.source.AvroSource
 
stop() - Method in class org.apache.flume.source.BasicSourceSemantics
 
stop() - Method in class org.apache.flume.source.EventDrivenSourceRunner
 
stop() - Method in class org.apache.flume.source.ExecSource
 
stop() - Method in class org.apache.flume.source.http.HTTPSource
 
stop() - Method in class org.apache.flume.source.MultiportSyslogTCPSource
 
stop() - Method in class org.apache.flume.source.NetcatSource
 
stop() - Method in class org.apache.flume.source.PollableSourceRunner
 
stop() - Method in class org.apache.flume.source.scribe.ScribeSource
 
stop() - Method in class org.apache.flume.source.SequenceGeneratorSource
 
stop() - Method in class org.apache.flume.source.SpoolDirectorySource
 
stop() - Method in class org.apache.flume.source.StressSource
 
stop() - Method in class org.apache.flume.source.SyslogTcpSource
 
stop() - Method in class org.apache.flume.source.SyslogUDPSource
 
stop() - Method in class org.apache.flume.source.thriftLegacy.ThriftLegacySource
 
stop() - Method in class org.apache.flume.source.ThriftSource
 
stop() - Method in class org.apache.flume.source.twitter.TwitterSource
 
STOP_OR_ERROR - Static variable in enum org.apache.flume.lifecycle.LifecycleState
 
stopAll(List<LifecycleAware>) - Static method in class org.apache.flume.lifecycle.LifecycleController
 
storeEvent(PersistableEvent, Connection) - Method in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
storeEvent(PersistableEvent, Connection) - Method in class org.apache.flume.channel.jdbc.impl.MySQLSchemaHandler
 
storeEvent(PersistableEvent, Connection) - Method in interface org.apache.flume.channel.jdbc.impl.SchemaHandler
Inserts the given persistent event into the database.
storePosition(long) - Method in class org.apache.flume.serialization.DurablePositionTracker
 
storePosition(long) - Method in interface org.apache.flume.serialization.PositionTracker
 
StressSource - Class in org.apache.flume.source
Internal load-generating source implementation.
StressSource() - Constructor for class org.apache.flume.source.StressSource
 
success - Variable in class org.apache.flume.source.scribe.Scribe.Log_result
 
success - Variable in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
 
success - Variable in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
 
supervise(LifecycleAware, LifecycleSupervisor.SupervisorPolicy, LifecycleState) - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
 
supervisoree - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.MonitorRunnable
 
supportsReopen() - Method in class org.apache.flume.serialization.AbstractAvroEventSerializer
 
supportsReopen() - Method in class org.apache.flume.serialization.BodyTextEventSerializer
 
supportsReopen() - Method in interface org.apache.flume.serialization.EventSerializer
Specify whether this output format supports reopening files for append.
supportsReopen() - Method in class org.apache.flume.serialization.HeaderAndBodyTextEventSerializer
 
supportsReopen() - Method in class org.apache.flume.sink.hdfs.AvroEventSerializer
 
sync() - Method in class org.apache.flume.sink.hdfs.HDFSCompressedDataStream
 
sync() - Method in class org.apache.flume.sink.hdfs.HDFSDataStream
 
sync() - Method in class org.apache.flume.sink.hdfs.HDFSSequenceFile
 
sync() - Method in interface org.apache.flume.sink.hdfs.HDFSWriter
 
SYNC_INTERVAL_BYTES - Static variable in class org.apache.flume.serialization.AvroEventSerializerConfigurationConstants
Avro sync interval, in approximate bytes
SYSLOG_BODY_POS - Static variable in class org.apache.flume.source.SyslogUtils
 
SYSLOG_FACILITY - Static variable in class org.apache.flume.source.SyslogUtils
 
SYSLOG_HOSTNAME_POS - Static variable in class org.apache.flume.source.SyslogUtils
 
SYSLOG_MSG_RFC3164_0 - Static variable in class org.apache.flume.source.SyslogUtils
 
SYSLOG_MSG_RFC5424_0 - Static variable in class org.apache.flume.source.SyslogUtils
 
SYSLOG_SEVERITY - Static variable in class org.apache.flume.source.SyslogUtils
 
SYSLOG_TIMESTAMP_FORMAT_RFC3164_1 - Static variable in class org.apache.flume.source.SyslogUtils
 
SYSLOG_TIMESTAMP_FORMAT_RFC5424_1 - Static variable in class org.apache.flume.source.SyslogUtils
 
SYSLOG_TIMESTAMP_FORMAT_RFC5424_2 - Static variable in class org.apache.flume.source.SyslogUtils
 
SYSLOG_TIMESTAMP_FORMAT_RFC5424_3 - Static variable in class org.apache.flume.source.SyslogUtils
 
SYSLOG_TIMESTAMP_FORMAT_RFC5424_4 - Static variable in class org.apache.flume.source.SyslogUtils
 
SYSLOG_TIMESTAMP_POS - Static variable in class org.apache.flume.source.SyslogUtils
 
SyslogParser - Class in org.apache.flume.source
 
SyslogParser() - Constructor for class org.apache.flume.source.SyslogParser
 
SyslogSourceConfigurationConstants - Class in org.apache.flume.source
 
SyslogTcpSource - Class in org.apache.flume.source
 
SyslogTcpSource() - Constructor for class org.apache.flume.source.SyslogTcpSource
 
SyslogTcpSource.syslogTcpHandler - Class in org.apache.flume.source
 
SyslogTcpSource.syslogTcpHandler() - Constructor for class org.apache.flume.source.SyslogTcpSource.syslogTcpHandler
 
SyslogUDPSource - Class in org.apache.flume.source
 
SyslogUDPSource() - Constructor for class org.apache.flume.source.SyslogUDPSource
 
SyslogUDPSource.syslogHandler - Class in org.apache.flume.source
 
SyslogUDPSource.syslogHandler() - Constructor for class org.apache.flume.source.SyslogUDPSource.syslogHandler
 
SyslogUtils - Class in org.apache.flume.source
 
SyslogUtils() - Constructor for class org.apache.flume.source.SyslogUtils
 
SyslogUtils(boolean) - Constructor for class org.apache.flume.source.SyslogUtils
 
SyslogUtils(Integer, boolean, boolean) - Constructor for class org.apache.flume.source.SyslogUtils
 
SyslogUtils.SyslogStatus - Enum in org.apache.flume.source
 
SYSPROP_CALLED_FROM_SERVICE - Static variable in class org.apache.flume.Constants
Disables the fail-fast startup behavior.
SystemClock - Class in org.apache.flume
Default implementation of Clock which uses System
SystemClock() - Constructor for class org.apache.flume.SystemClock
 

T

TAG_REGEX - Static variable in class org.apache.flume.formatter.output.BucketPath
These are useful to other classes which might want to search for tags in strings.
tagPattern - Static variable in class org.apache.flume.formatter.output.BucketPath
 
take() - Method in class org.apache.flume.channel.BasicChannelSemantics
Ensures that a transaction exists for this thread and then delegates the take to the thread's BasicTransactionSemantics instance.
take() - Method in class org.apache.flume.channel.BasicTransactionSemantics
The method to which BasicChannelSemantics delegates calls to take.
take(Channel) - Static method in class org.apache.flume.channel.ChannelUtils
A convenience method for single-event take transactions.
take(Channel, int) - Static method in class org.apache.flume.channel.ChannelUtils
A convenience method for multiple-event take transactions.
take() - Method in class org.apache.flume.channel.jdbc.JdbcChannel
 
take() - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel
 
take() - Method in interface org.apache.flume.Channel
Returns the next event from the channel if available.
takeOverflow(int) - Method in class org.apache.flume.channel.SpillableMemoryChannel.DrainOrderQueue
 
takePrimary(int) - Method in class org.apache.flume.channel.SpillableMemoryChannel.DrainOrderQueue
 
tell() - Method in class org.apache.flume.serialization.ResettableFileInputStream
 
tell() - Method in class org.apache.flume.serialization.ResettableInputStream
Tell the current byte position.
tell() - Method in interface org.apache.flume.serialization.Seekable
 
TextDelimitedOutputFormatter - Class in org.apache.flume.formatter.output
Deprecated.
TextDelimitedOutputFormatter() - Constructor for class org.apache.flume.formatter.output.TextDelimitedOutputFormatter
Deprecated.
 
ThriftFlumeEvent - Class in com.cloudera.flume.handlers.thrift
 
ThriftFlumeEvent() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
ThriftFlumeEvent(long, Priority, ByteBuffer, long, String, Map<String, ByteBuffer>) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
ThriftFlumeEvent(ThriftFlumeEvent) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Performs a deep copy on other.
ThriftFlumeEvent - Class in org.apache.flume.thrift
 
ThriftFlumeEvent() - Constructor for class org.apache.flume.thrift.ThriftFlumeEvent
 
ThriftFlumeEvent(Map<String, String>, ByteBuffer) - Constructor for class org.apache.flume.thrift.ThriftFlumeEvent
 
ThriftFlumeEvent(ThriftFlumeEvent) - Constructor for class org.apache.flume.thrift.ThriftFlumeEvent
Performs a deep copy on other.
ThriftFlumeEvent._Fields - Enum in com.cloudera.flume.handlers.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftFlumeEvent._Fields - Enum in org.apache.flume.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftFlumeEventServer - Class in com.cloudera.flume.handlers.thrift
 
ThriftFlumeEventServer() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer
 
ThriftFlumeEventServer.append_args - Class in com.cloudera.flume.handlers.thrift
 
ThriftFlumeEventServer.append_args() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
 
ThriftFlumeEventServer.append_args(ThriftFlumeEvent) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
 
ThriftFlumeEventServer.append_args(ThriftFlumeEventServer.append_args) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Performs a deep copy on other.
ThriftFlumeEventServer.append_args._Fields - Enum in com.cloudera.flume.handlers.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftFlumeEventServer.AsyncClient - Class in com.cloudera.flume.handlers.thrift
 
ThriftFlumeEventServer.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient
 
ThriftFlumeEventServer.AsyncClient.append_call - Class in com.cloudera.flume.handlers.thrift
 
ThriftFlumeEventServer.AsyncClient.append_call(ThriftFlumeEvent, AsyncMethodCallback<ThriftFlumeEventServer.AsyncClient.append_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.append_call
 
ThriftFlumeEventServer.AsyncClient.close_call - Class in com.cloudera.flume.handlers.thrift
 
ThriftFlumeEventServer.AsyncClient.close_call(AsyncMethodCallback<ThriftFlumeEventServer.AsyncClient.close_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.close_call
 
ThriftFlumeEventServer.AsyncClient.Factory - Class in com.cloudera.flume.handlers.thrift
 
ThriftFlumeEventServer.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.Factory
 
ThriftFlumeEventServer.AsyncIface - Interface in com.cloudera.flume.handlers.thrift
 
ThriftFlumeEventServer.Client - Class in com.cloudera.flume.handlers.thrift
 
ThriftFlumeEventServer.Client(TProtocol) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
 
ThriftFlumeEventServer.Client(TProtocol, TProtocol) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
 
ThriftFlumeEventServer.Client.Factory - Class in com.cloudera.flume.handlers.thrift
 
ThriftFlumeEventServer.Client.Factory() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client.Factory
 
ThriftFlumeEventServer.close_args - Class in com.cloudera.flume.handlers.thrift
 
ThriftFlumeEventServer.close_args() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
 
ThriftFlumeEventServer.close_args(ThriftFlumeEventServer.close_args) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Performs a deep copy on other.
ThriftFlumeEventServer.close_args._Fields - Enum in com.cloudera.flume.handlers.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftFlumeEventServer.close_result - Class in com.cloudera.flume.handlers.thrift
 
ThriftFlumeEventServer.close_result() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
 
ThriftFlumeEventServer.close_result(ThriftFlumeEventServer.close_result) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Performs a deep copy on other.
ThriftFlumeEventServer.close_result._Fields - Enum in com.cloudera.flume.handlers.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftFlumeEventServer.Iface - Interface in com.cloudera.flume.handlers.thrift
 
ThriftFlumeEventServer.Processor<I extends ThriftFlumeEventServer.Iface> - Class in com.cloudera.flume.handlers.thrift
 
ThriftFlumeEventServer.Processor(I) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Processor
 
ThriftFlumeEventServer.Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Processor
 
ThriftLegacySource - Class in org.apache.flume.source.thriftLegacy
 
ThriftLegacySource() - Constructor for class org.apache.flume.source.thriftLegacy.ThriftLegacySource
 
ThriftLegacySource.ThriftHandler - Class in org.apache.flume.source.thriftLegacy
 
ThriftLegacySource.ThriftHandler(TServer) - Constructor for class org.apache.flume.source.thriftLegacy.ThriftLegacySource.ThriftHandler
 
ThriftRpcClient - Class in org.apache.flume.api
 
ThriftRpcClient() - Constructor for class org.apache.flume.api.ThriftRpcClient
 
ThriftSink - Class in org.apache.flume.sink
A Sink implementation that can send events to an RPC server (such as Flume's ThriftSource).
ThriftSink() - Constructor for class org.apache.flume.sink.ThriftSink
 
ThriftSource - Class in org.apache.flume.source
 
ThriftSource() - Constructor for class org.apache.flume.source.ThriftSource
 
ThriftSourceProtocol - Class in org.apache.flume.thrift
 
ThriftSourceProtocol() - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol
 
ThriftSourceProtocol.append_args - Class in org.apache.flume.thrift
 
ThriftSourceProtocol.append_args() - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.append_args
 
ThriftSourceProtocol.append_args(ThriftFlumeEvent) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.append_args
 
ThriftSourceProtocol.append_args(ThriftSourceProtocol.append_args) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.append_args
Performs a deep copy on other.
ThriftSourceProtocol.append_args._Fields - Enum in org.apache.flume.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftSourceProtocol.append_result - Class in org.apache.flume.thrift
 
ThriftSourceProtocol.append_result() - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.append_result
 
ThriftSourceProtocol.append_result(Status) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.append_result
 
ThriftSourceProtocol.append_result(ThriftSourceProtocol.append_result) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.append_result
Performs a deep copy on other.
ThriftSourceProtocol.append_result._Fields - Enum in org.apache.flume.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftSourceProtocol.appendBatch_args - Class in org.apache.flume.thrift
 
ThriftSourceProtocol.appendBatch_args() - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
ThriftSourceProtocol.appendBatch_args(List<ThriftFlumeEvent>) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
ThriftSourceProtocol.appendBatch_args(ThriftSourceProtocol.appendBatch_args) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
Performs a deep copy on other.
ThriftSourceProtocol.appendBatch_args._Fields - Enum in org.apache.flume.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftSourceProtocol.appendBatch_result - Class in org.apache.flume.thrift
 
ThriftSourceProtocol.appendBatch_result() - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
 
ThriftSourceProtocol.appendBatch_result(Status) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
 
ThriftSourceProtocol.appendBatch_result(ThriftSourceProtocol.appendBatch_result) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
Performs a deep copy on other.
ThriftSourceProtocol.appendBatch_result._Fields - Enum in org.apache.flume.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftSourceProtocol.AsyncClient - Class in org.apache.flume.thrift
 
ThriftSourceProtocol.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.AsyncClient
 
ThriftSourceProtocol.AsyncClient.append_call - Class in org.apache.flume.thrift
 
ThriftSourceProtocol.AsyncClient.append_call(ThriftFlumeEvent, AsyncMethodCallback<ThriftSourceProtocol.AsyncClient.append_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.AsyncClient.append_call
 
ThriftSourceProtocol.AsyncClient.appendBatch_call - Class in org.apache.flume.thrift
 
ThriftSourceProtocol.AsyncClient.appendBatch_call(List<ThriftFlumeEvent>, AsyncMethodCallback<ThriftSourceProtocol.AsyncClient.appendBatch_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.AsyncClient.appendBatch_call
 
ThriftSourceProtocol.AsyncClient.Factory - Class in org.apache.flume.thrift
 
ThriftSourceProtocol.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.AsyncClient.Factory
 
ThriftSourceProtocol.AsyncIface - Interface in org.apache.flume.thrift
 
ThriftSourceProtocol.Client - Class in org.apache.flume.thrift
 
ThriftSourceProtocol.Client(TProtocol) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.Client
 
ThriftSourceProtocol.Client(TProtocol, TProtocol) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.Client
 
ThriftSourceProtocol.Client.Factory - Class in org.apache.flume.thrift
 
ThriftSourceProtocol.Client.Factory() - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.Client.Factory
 
ThriftSourceProtocol.Iface - Interface in org.apache.flume.thrift
 
ThriftSourceProtocol.Processor<I extends ThriftSourceProtocol.Iface> - Class in org.apache.flume.thrift
 
ThriftSourceProtocol.Processor(I) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.Processor
 
ThriftSourceProtocol.Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.flume.thrift.ThriftSourceProtocol.Processor
 
TIME_ZONE - Static variable in class org.apache.flume.sink.elasticsearch.TimeBasedIndexNameBuilder
 
TimeBasedIndexNameBuilder - Class in org.apache.flume.sink.elasticsearch
Default index name builder.
TimeBasedIndexNameBuilder() - Constructor for class org.apache.flume.sink.elasticsearch.TimeBasedIndexNameBuilder
 
timestamp - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
TIMESTAMP - Static variable in class org.apache.flume.interceptor.TimestampInterceptor.Constants
 
TIMESTAMP - Static variable in class org.apache.flume.source.avroLegacy.AvroLegacySource
 
TimestampInterceptor - Class in org.apache.flume.interceptor
Simple Interceptor class that sets the current system timestamp on all events that are intercepted.
TimestampInterceptor.Builder - Class in org.apache.flume.interceptor
Builder which builds new instances of the TimestampInterceptor.
TimestampInterceptor.Builder() - Constructor for class org.apache.flume.interceptor.TimestampInterceptor.Builder
 
TimestampInterceptor.Constants - Class in org.apache.flume.interceptor
 
TimestampInterceptor.Constants() - Constructor for class org.apache.flume.interceptor.TimestampInterceptor.Constants
 
TimestampRoundDownUtil - Class in org.apache.flume.tools
 
TimestampRoundDownUtil() - Constructor for class org.apache.flume.tools.TimestampRoundDownUtil
 
toBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
toBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
toBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
toBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
toBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
toBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
toBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
toBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
toBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
toBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
toBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
toBuilder() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
toString() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
toString() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
 
toString() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
 
toString() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
 
toString() - Method in class org.apache.flume.api.HostInfo
 
toString() - Method in class org.apache.flume.api.NettyAvroRpcClient
 
toString() - Method in class org.apache.flume.channel.AbstractChannel
 
toString() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
toString() - Method in class org.apache.flume.channel.file.FileChannel
 
toString() - Method in enum org.apache.flume.channel.jdbc.DatabaseType
 
toString() - Method in enum org.apache.flume.channel.jdbc.TransactionIsolation
 
toString() - Method in enum org.apache.flume.clients.log4jappender.Log4jAvroHeaders
 
toString() - Method in class org.apache.flume.conf.ComponentConfiguration
 
toString(int) - Method in class org.apache.flume.conf.ComponentConfiguration
 
toString(int) - Method in class org.apache.flume.conf.sink.SinkConfiguration
 
toString(int) - Method in class org.apache.flume.conf.source.SourceConfiguration
 
toString() - Method in class org.apache.flume.Context
 
toString() - Method in class org.apache.flume.CounterGroup
 
toString() - Method in class org.apache.flume.event.SimpleEvent
 
toString() - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
 
toString() - Method in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
toString() - Method in class org.apache.flume.node.PollingPropertiesFileConfigurationProvider
 
toString() - Method in class org.apache.flume.node.SimpleMaterializedConfiguration
 
toString() - Method in class org.apache.flume.sink.AbstractRpcSink
 
toString() - Method in class org.apache.flume.sink.AbstractSink
 
toString() - Method in class org.apache.flume.sink.hdfs.HDFSEventSink
 
toString() - Method in class org.apache.flume.sink.hdfs.KerberosUser
 
toString() - Method in class org.apache.flume.sink.NullSink
 
toString() - Method in class org.apache.flume.sink.solr.morphline.MorphlineSink
 
toString() - Method in class org.apache.flume.SinkRunner
 
toString() - Method in class org.apache.flume.source.AbstractSource
 
toString() - Method in class org.apache.flume.source.AvroSource
 
toString() - Method in class org.apache.flume.source.BasicSourceSemantics
 
toString() - Method in class org.apache.flume.source.EventDrivenSourceRunner
 
toString() - Method in class org.apache.flume.source.MultiportSyslogTCPSource
 
toString() - Method in class org.apache.flume.source.PollableSourceRunner
 
toString() - Method in class org.apache.flume.source.scribe.LogEntry
 
toString() - Method in class org.apache.flume.source.scribe.Scribe.Log_args
 
toString() - Method in class org.apache.flume.source.scribe.Scribe.Log_result
 
toString() - Method in class org.apache.flume.source.SpoolDirectorySource
 
toString() - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
toString() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
 
toString() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
 
toString() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
toString() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
 
totalPuts - Variable in class org.apache.flume.channel.SpillableMemoryChannel.DrainOrderQueue
 
TRACKER_DIR - Static variable in class org.apache.flume.source.SpoolDirectorySourceConfigurationConstants
Directory to store metadata about files being processed
trackerDirPath(String) - Method in class org.apache.flume.client.avro.ReliableSpoolingFileEventReader.Builder
 
transact(Channel, Runnable) - Static method in class org.apache.flume.channel.ChannelUtils
A convenience method for transactions that don't require a return value.
transact(Channel, Callable<T>) - Static method in class org.apache.flume.channel.ChannelUtils
A general optimistic implementation of Transaction client semantics.
Transaction - Interface in org.apache.flume
Provides the transaction boundary while accessing a channel.
Transaction.TransactionState - Enum in org.apache.flume
 
TRANSACTION_CAPACITY - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
Maximum number of put/take events in a transaction.
transactionCapacity - Variable in class org.apache.flume.channel.file.FileChannel
 
TransactionEventRecord - Class in org.apache.flume.channel.file
Base class for records in data file: Put, Take, Rollback, Commit
TransactionEventRecord(long, long) - Constructor for class org.apache.flume.channel.file.TransactionEventRecord
 
TRANSACTIONID_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
TransactionIDOracle - Class in org.apache.flume.channel.file
 
TransactionIsolation - Enum in org.apache.flume.channel.jdbc
 
TransportClient - Static variable in class org.apache.flume.sink.elasticsearch.client.ElasticSearchClientFactory
 
TTL - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
TTL in days, when set will cause the expired documents to be deleted automatically, if not set documents will never be automatically deleted
TTL_REGEX - Static variable in class org.apache.flume.sink.elasticsearch.ElasticSearchSinkConstants
 
TwitterSource - Class in org.apache.flume.source.twitter
Demo Flume source that connects via Streaming API to the 1% sample twitter firehose, continously downloads tweets, converts them to Avro format and sends Avro events to a downstream Flume sink.
TwitterSource() - Constructor for class org.apache.flume.source.twitter.TwitterSource
 
TYPE_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
TYPE_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 

U

unknown(String, String, String, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
unregisterCurrentStream() - Method in class org.apache.flume.sink.hdfs.AbstractHDFSWriter
 
unsetBody() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
unsetBody() - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
unsetCategory() - Method in class org.apache.flume.source.scribe.LogEntry
 
unsetEvent() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
 
unsetEvents() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
unsetEvt() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
 
unsetFields() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
unsetHeaders() - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
unsetHost() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
unsetMessage() - Method in class org.apache.flume.source.scribe.LogEntry
 
unsetMessages() - Method in class org.apache.flume.source.scribe.Scribe.Log_args
 
unsetNanos() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
unsetPriority() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
unsetSuccess() - Method in class org.apache.flume.source.scribe.Scribe.Log_result
 
unsetSuccess() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
 
unsetSuccess() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
 
unsetTimestamp() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
unsupervise(LifecycleAware) - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
 
updateCurrentChannelSize(long) - Method in class org.apache.flume.channel.jdbc.impl.JdbcChannelProviderImpl
A callback method invoked from individual transaction instances after a successful commit.
USE_DUAL_CHECKPOINTS - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
 
USE_FAST_REPLAY - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
 
USE_IP - Static variable in class org.apache.flume.interceptor.HostInterceptor.Constants
 
USE_IP_DFLT - Static variable in class org.apache.flume.interceptor.HostInterceptor.Constants
 
USE_LOG_REPLAY_V1 - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
Turn on Flume 1.2 log replay logic
USERNAME - Static variable in class org.apache.flume.source.jms.JMSSourceConfiguration
 
UUIDInterceptor - Class in org.apache.flume.sink.solr.morphline
Flume Interceptor that sets a universally unique identifier on all events that are intercepted.
UUIDInterceptor(Context) - Constructor for class org.apache.flume.sink.solr.morphline.UUIDInterceptor
 
UUIDInterceptor.Builder - Class in org.apache.flume.sink.solr.morphline
Builder implementations MUST have a public no-arg constructor
UUIDInterceptor.Builder() - Constructor for class org.apache.flume.sink.solr.morphline.UUIDInterceptor.Builder
 

V

validate() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
validate() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
 
validate() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
 
validate() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
 
validate() - Method in class org.apache.flume.source.scribe.LogEntry
 
validate() - Method in class org.apache.flume.source.scribe.Scribe.Log_args
 
validate() - Method in class org.apache.flume.source.scribe.Scribe.Log_result
 
validate() - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
validate() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
 
validate() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
 
validate() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
validate() - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
 
validateSchema() - Method in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
validateSchema() - Method in class org.apache.flume.channel.jdbc.impl.MySQLSchemaHandler
 
validateSchema() - Method in interface org.apache.flume.channel.jdbc.impl.SchemaHandler
Validates the schema.
VALUE - Static variable in class org.apache.flume.interceptor.StaticInterceptor.Constants
 
VALUE_DEFAULT - Static variable in class org.apache.flume.interceptor.StaticInterceptor.Constants
 
VALUE_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
valueOf(String) - Static method in enum com.cloudera.flume.handlers.thrift.EventStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.cloudera.flume.handlers.thrift.Priority
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.api.RpcClientFactory.ClientType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.channel.BasicTransactionSemantics.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.channel.file.encryption.CipherProviderType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.channel.file.encryption.KeyProviderType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.channel.jdbc.DatabaseType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.channel.jdbc.TransactionIsolation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.clients.log4jappender.Log4jAvroHeaders
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.conf.channel.ChannelConfiguration.ChannelConfigurationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.conf.channel.ChannelSelectorConfiguration.ChannelSelectorConfigurationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.conf.channel.ChannelSelectorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.conf.channel.ChannelType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.conf.ComponentConfiguration.ComponentType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.conf.FlumeConfigurationError.ErrorOrWarning
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.conf.FlumeConfigurationErrorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.conf.sink.SinkConfiguration.SinkConfigurationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.conf.sink.SinkProcessorConfiguration.SinkProcessorConfigurationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.conf.sink.SinkProcessorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.conf.sink.SinkType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.conf.source.SourceConfiguration.SourceConfigurationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.conf.source.SourceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.instrumentation.MonitoredCounterGroup.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.instrumentation.MonitoringType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.interceptor.InterceptorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.lifecycle.LifecycleState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.PollableSource.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.serialization.AvroEventDeserializer.AvroSchemaType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.serialization.DecodeErrorPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.serialization.EventDeserializerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.serialization.EventSerializerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.sink.hbase.SimpleHbaseEventSerializer.KeyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.sink.hdfs.SequenceFileSerializerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.Sink.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.source.jms.JMSDestinationLocator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.source.jms.JMSDestinationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.source.scribe.LogEntry._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.source.scribe.ResultCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.source.scribe.Scribe.Log_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.source.scribe.Scribe.Log_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.source.SpoolDirectorySourceConfigurationConstants.ConsumeOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.source.SyslogUtils.SyslogStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.thrift.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.thrift.ThriftFlumeEvent._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.tools.FlumeToolType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.Transaction.TransactionState
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.cloudera.flume.handlers.thrift.EventStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.cloudera.flume.handlers.thrift.Priority
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.api.RpcClientFactory.ClientType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.channel.BasicTransactionSemantics.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.channel.file.encryption.CipherProviderType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.channel.file.encryption.KeyProviderType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.channel.jdbc.DatabaseType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.channel.jdbc.TransactionIsolation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.clients.log4jappender.Log4jAvroHeaders
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.conf.channel.ChannelConfiguration.ChannelConfigurationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.conf.channel.ChannelSelectorConfiguration.ChannelSelectorConfigurationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.conf.channel.ChannelSelectorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.conf.channel.ChannelType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.conf.ComponentConfiguration.ComponentType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.conf.FlumeConfigurationError.ErrorOrWarning
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.conf.FlumeConfigurationErrorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.conf.sink.SinkConfiguration.SinkConfigurationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.conf.sink.SinkProcessorConfiguration.SinkProcessorConfigurationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.conf.sink.SinkProcessorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.conf.sink.SinkType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.conf.source.SourceConfiguration.SourceConfigurationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.conf.source.SourceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.instrumentation.MonitoredCounterGroup.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.instrumentation.MonitoringType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.interceptor.InterceptorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.lifecycle.LifecycleState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.PollableSource.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.serialization.AvroEventDeserializer.AvroSchemaType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.serialization.DecodeErrorPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.serialization.EventDeserializerType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.serialization.EventSerializerType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.sink.hbase.SimpleHbaseEventSerializer.KeyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.sink.hdfs.SequenceFileSerializerType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.Sink.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.source.jms.JMSDestinationLocator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.source.jms.JMSDestinationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.source.scribe.LogEntry._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.source.scribe.ResultCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.source.scribe.Scribe.Log_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.source.scribe.Scribe.Log_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.source.SpoolDirectorySourceConfigurationConstants.ConsumeOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.source.SyslogUtils.SyslogStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.thrift.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.thrift.ThriftFlumeEvent._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.append_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.tools.FlumeToolType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.Transaction.TransactionState
Returns an array containing the constants of this enum type, in the order they are declared.
VERSION_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
VERSION_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
VersionAnnotation - Annotation Type in org.apache.flume
This class is about package attribute that captures version info of Flume that was compiled.
VersionInfo - Class in org.apache.flume.tools
 
VersionInfo() - Constructor for class org.apache.flume.tools.VersionInfo
 

W

waitForOneOf(LifecycleAware, LifecycleState[]) - Static method in class org.apache.flume.lifecycle.LifecycleController
 
waitForOneOf(LifecycleAware, LifecycleState[], long) - Static method in class org.apache.flume.lifecycle.LifecycleController
 
waitForState(LifecycleAware, LifecycleState) - Static method in class org.apache.flume.lifecycle.LifecycleController
 
waitForState(LifecycleAware, LifecycleState, long) - Static method in class org.apache.flume.lifecycle.LifecycleController
 
withBody(byte[], Map<String, String>) - Static method in class org.apache.flume.event.EventBuilder
Instantiate an Event instance based on the provided body and headers.
withBody(byte[]) - Static method in class org.apache.flume.event.EventBuilder
 
withBody(String, Charset, Map<String, String>) - Static method in class org.apache.flume.event.EventBuilder
 
withBody(String, Charset) - Static method in class org.apache.flume.event.EventBuilder
 
write(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
 
write(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
 
write(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
 
write(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
 
write(DataOutput) - Method in class org.apache.flume.channel.file.TransactionEventRecord
 
write(Event) - Method in class org.apache.flume.serialization.AbstractAvroEventSerializer
 
write(Event) - Method in class org.apache.flume.serialization.BodyTextEventSerializer
 
write(Event) - Method in interface org.apache.flume.serialization.EventSerializer
Serialize and write the given event.
write(Event) - Method in class org.apache.flume.serialization.HeaderAndBodyTextEventSerializer
 
write(Event) - Method in class org.apache.flume.sink.hdfs.AvroEventSerializer
 
write(TProtocol) - Method in class org.apache.flume.source.scribe.LogEntry
 
write(TProtocol) - Method in class org.apache.flume.source.scribe.Scribe.Log_args
 
write(TProtocol) - Method in class org.apache.flume.source.scribe.Scribe.Log_result
 
write(TProtocol) - Method in class org.apache.flume.thrift.ThriftFlumeEvent
 
write(TProtocol) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_args
 
write(TProtocol) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.append_result
 
write(TProtocol) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_args
 
write(TProtocol) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.appendBatch_result
 
write_args(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.append_call
 
write_args(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.close_call
 
write_args(TProtocol) - Method in class org.apache.flume.source.scribe.Scribe.AsyncClient.Log_call
 
write_args(TProtocol) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.AsyncClient.append_call
 
write_args(TProtocol) - Method in class org.apache.flume.thrift.ThriftSourceProtocol.AsyncClient.appendBatch_call
 
writeDelimitedBuffer(ByteBuffer, ByteBuffer) - Static method in class org.apache.flume.channel.file.LogFile
 
writeDelimitedTo(GeneratedMessage, File) - Static method in class org.apache.flume.channel.file.LogFileV3
Writes a GeneratedMessage to a temp file, synchronizes it to disk and then renames the file over file.
WRITEORDERID_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
WRITEORDERID_FIELD_NUMBER - Static variable in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
WriteOrderOracle - Class in org.apache.flume.channel.file
 
writeReplace() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
writeReplace() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
writeReplace() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
writeReplace() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
writeReplace() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
writeReplace() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
writeReplace() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
writeReplace() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
writeReplace() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
writeReplace() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
writeReplace() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
writeReplace() - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 
writeTo(CodedOutputStream) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.ActiveLog
 
writeTo(CodedOutputStream) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Checkpoint
 
writeTo(CodedOutputStream) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Commit
 
writeTo(CodedOutputStream) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEvent
 
writeTo(CodedOutputStream) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeader
 
writeTo(CodedOutputStream) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryption
 
writeTo(CodedOutputStream) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaData
 
writeTo(CodedOutputStream) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Put
 
writeTo(CodedOutputStream) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Rollback
 
writeTo(CodedOutputStream) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.Take
 
writeTo(CodedOutputStream) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooter
 
writeTo(CodedOutputStream) - Method in class org.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeader
 

X

xdr_int(int) - Method in class org.apache.flume.instrumentation.GangliaServer
Puts an integer into the buffer as 4 bytes, big-endian.
xdr_string(String) - Method in class org.apache.flume.instrumentation.GangliaServer
Puts a string into the buffer by first writing the size of the string as an int, followed by the bytes of the string, padded if necessary to a multiple of 4.

Z

ZK_QUORUM - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
 
ZK_ZNODE_PARENT - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
 
A B C D E F G H I J K L M N O P Q R S T U V W X Z 

Copyright © 2009-2014 Apache Software Foundation. All Rights Reserved.