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

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
 
AbstractFileConfigurationProvider - Class in org.apache.flume.conf.file
 
AbstractFileConfigurationProvider() - Constructor for class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
AbstractFileConfigurationProvider.FileWatcherRunnable - Class in org.apache.flume.conf.file
 
AbstractFileConfigurationProvider.FileWatcherRunnable() - Constructor for class org.apache.flume.conf.file.AbstractFileConfigurationProvider.FileWatcherRunnable
 
AbstractLogicalNodeManager - Class in org.apache.flume.node.nodemanager
 
AbstractLogicalNodeManager() - Constructor for class org.apache.flume.node.nodemanager.AbstractLogicalNodeManager
 
AbstractRpcClient - Class in org.apache.flume.api
 
AbstractRpcClient() - Constructor for class org.apache.flume.api.AbstractRpcClient
 
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.Log4jAppender
Activate the options set using setPort() and setHostname()
add(CounterGroup) - Method in class org.apache.flume.CounterGroup
 
add(LifecycleAware) - Method in class org.apache.flume.node.nodemanager.AbstractLogicalNodeManager
 
add(LifecycleAware) - Method in interface org.apache.flume.node.NodeManager
 
add(LifecycleAware) - Method in class org.apache.flume.node.nodemanager.DefaultLogicalNodeManager
 
addAndGet(String, Long) - Method in class org.apache.flume.CounterGroup
 
addAndGet(String, long) - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
 
addFormats(Map<String, String>) - Method in class org.apache.flume.source.SyslogUtils
 
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
 
addToEventTakeSuccessCount(long) - Method in class org.apache.flume.instrumentation.ChannelCounter
 
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.
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().
allocate(int) - Static method in class org.apache.flume.tools.DirectMemoryUtils
 
append(ThriftFlumeEvent, AsyncMethodCallback<ThriftFlumeEventServer.AsyncClient.append_call>) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient
Deprecated.  
append(ThriftFlumeEvent, AsyncMethodCallback<ThriftFlumeEventServer.AsyncClient.append_call>) - Method in interface com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncIface
Deprecated.  
append(ThriftFlumeEvent) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
append(ThriftFlumeEvent) - Method in interface com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Iface
Deprecated.  
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(LoggingEvent) - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
Append the LoggingEvent, to send to the first Flume hop.
append(Event, FlumeFormatter) - Method in class org.apache.flume.sink.hdfs.HDFSCompressedDataStream
 
append(Event, FlumeFormatter) - Method in class org.apache.flume.sink.hdfs.HDFSDataStream
 
append(Event, FlumeFormatter) - Method in class org.apache.flume.sink.hdfs.HDFSSequenceFile
 
append(Event, FlumeFormatter) - 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
 
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<AvroFlumeEvent>) - Method in class org.apache.flume.source.AvroSource
 
Application - Class in org.apache.flume.node
 
Application() - 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
 
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
 
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

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
 
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.
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.
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.
body - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
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
 
BucketPath - Class in org.apache.flume.formatter.output
 
BucketPath() - Constructor for class org.apache.flume.formatter.output.BucketPath
 
bufferForBody() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
build() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.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.TimestampInterceptor.Builder
 
build(Context, OutputStream) - Method in class org.apache.flume.serialization.BodyTextEventSerializer.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
 

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.recoverable.memory.RecoverableMemoryChannel
Deprecated.  
cf - Variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
 
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.
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 - Class in org.apache.flume.instrumentation
 
ChannelCounter(String) - Constructor for class org.apache.flume.instrumentation.ChannelCounter
 
ChannelCounterMBean - Interface in org.apache.flume.instrumentation
 
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
 
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.
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.
CHECKPOINT_WRITE_TIMEOUT - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
The amount of time in seconds the channel should wait to write the checkpoint when some other operation(s) are enqueued or in progress.
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
Deprecated.  
clear() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
clear() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
clear() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
clear() - Method in class org.apache.flume.Context
Removes all of the mappings from this map.
close(AsyncMethodCallback<ThriftFlumeEventServer.AsyncClient.close_call>) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient
Deprecated.  
close(AsyncMethodCallback<ThriftFlumeEventServer.AsyncClient.close_call>) - Method in interface com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncIface
Deprecated.  
close() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
close() - Method in interface com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Iface
Deprecated.  
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.channel.BasicTransactionSemantics
 
close() - Method in class org.apache.flume.channel.ChannelProcessor
 
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 class org.apache.flume.channel.recoverable.memory.wal.SequenceIDBuffer
 
close() - Method in class org.apache.flume.channel.recoverable.memory.wal.WAL
 
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.TimestampInterceptor
 
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 interface org.apache.flume.Transaction
Ends a transaction boundary for the current channel operation.
COL_NAME_CONFIG - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
Comma separated list of column names to place matching groups in.
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.Transaction
Indicates that the transaction can be successfully committed.
compare(int, int) - Method in class org.apache.flume.channel.recoverable.memory.wal.SequenceIDBuffer
 
compareTo(ThriftFlumeEvent) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
compareTo(ThriftFlumeEventServer.append_args) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
compareTo(ThriftFlumeEventServer.close_args) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
compareTo(ThriftFlumeEventServer.close_result) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
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.
CONFIG_BATCH_SIZE - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
Configuration key used to specify the batch size.
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_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_CLIENT_TYPE - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
Configuration key to specify the RpcClient type to be used.
CONFIG_COLUMN_FAMILY - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
The column family which the sink should use.
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_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_FORMAT_PREFIX - Static variable in class org.apache.flume.source.SyslogSourceConfigurationConstants
 
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_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_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_PASSWORD - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
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_PREFIX_MAPPING - Static variable in class org.apache.flume.channel.MultiplexingChannelSelector
 
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_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_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_TABLE - Static variable in class org.apache.flume.sink.hbase.HBaseSinkConfigurationConstants
The Hbase table which the sink should write to.
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(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(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
 
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.recoverable.memory.RecoverableMemoryChannel
Deprecated.  
configure(Context) - Method in class org.apache.flume.channel.ReplicatingChannelSelector
 
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.interceptor.HostInterceptor.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.serialization.BodyTextEventSerializer
 
configure(Context) - Method in class org.apache.flume.sink.AbstractSinkSelector
 
configure(Context) - Method in class org.apache.flume.sink.AvroSink
 
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.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.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.source.avroLegacy.AvroLegacySource
 
configure(Context) - Method in class org.apache.flume.source.AvroSource
 
configure(Context) - Method in class org.apache.flume.source.ExecSource
 
configure(Context) - Method in class org.apache.flume.source.NetcatSource
 
configure(Context) - Method in class org.apache.flume.source.StressSource
 
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
 
configured - Variable in class org.apache.flume.conf.ComponentConfiguration
 
connectTimeout - Variable in class org.apache.flume.api.AbstractRpcClient
 
Constants - Class in org.apache.flume
 
containsTag(String) - Static method in class org.apache.flume.formatter.output.BucketPath
Returns true if in contains a substring matching TAG_REGEX (i.e.
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
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(String, String) - Method in interface org.apache.flume.SourceFactory
 
createHostIterator() - Method in interface org.apache.flume.api.LoadBalancingRpcClient.HostSelector
 
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.recoverable.memory.RecoverableMemoryChannel
Deprecated.  
CTX_PREFIX - Static variable in interface org.apache.flume.serialization.EventSerializer
Context prefix

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
 
deepCopy() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
deepCopy() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
deepCopy() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
deepCopy() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
DEFAULT_BATCH_SIZE - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
Default batch size.
DEFAULT_CAPACITY - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
 
DEFAULT_CAPACITY - Static variable in class org.apache.flume.channel.recoverable.memory.RecoverableMemoryChannel
Deprecated.  
DEFAULT_CHECKPOINT_INTERVAL - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
 
DEFAULT_CHECKPOINT_WRITE_TIMEOUT - 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_COMPRESSION_CODEC - Static variable in class org.apache.flume.serialization.AvroEventSerializerConfigurationConstants
 
DEFAULT_CONNECT_TIMEOUT_MILLIS - Static variable in class org.apache.flume.api.RpcClientConfigurationConstants
Default connection, handshake, and initial request timeout in milliseconds.
DEFAULT_KEEP_ALIVE - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
 
DEFAULT_KEEPALIVE - Static variable in class org.apache.flume.channel.recoverable.memory.RecoverableMemoryChannel
Deprecated.  
DEFAULT_LOG_STDERR - Static variable in class org.apache.flume.source.ExecSourceConfigurationConstants
 
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_MAX_LOGS_SIZE - Static variable in class org.apache.flume.channel.recoverable.memory.wal.WAL
Number of bytes, to keep before we start pruning logs.
DEFAULT_MIN_LOG_RETENTION_PERIOD - Static variable in class org.apache.flume.channel.recoverable.memory.wal.WAL
Minimum number of ms to keep a log file.
DEFAULT_MULTIPLEX_HEADER - Static variable in class org.apache.flume.channel.MultiplexingChannelSelector
 
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_ROLL_SIZE - Static variable in class org.apache.flume.channel.recoverable.memory.wal.WAL
Number of bytes before we roll the file.
DEFAULT_SIZE - Static variable in class org.apache.flume.source.SyslogUtils
 
DEFAULT_SYNC_INTERVAL_BYTES - Static variable in class org.apache.flume.serialization.AvroEventSerializerConfigurationConstants
 
DEFAULT_TRANSACTION_CAPACITY - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
 
DEFAULT_WORKER_INTERVAL - Static variable in class org.apache.flume.channel.recoverable.memory.wal.WAL
How often in ms the background worker runs
DEFAULT_WRITE_TIMEOUT - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
 
DefaultChannelFactory - Class in org.apache.flume.channel
 
DefaultChannelFactory() - Constructor for class org.apache.flume.channel.DefaultChannelFactory
 
DefaultLogicalNodeManager - Class in org.apache.flume.node.nodemanager
 
DefaultLogicalNodeManager() - Constructor for class org.apache.flume.node.nodemanager.DefaultLogicalNodeManager
 
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
 
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
 
desiredState - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
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
 
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
 
doCommit() - Method in class org.apache.flume.channel.MemoryChannel.MemoryTransaction
 
doPut(Event) - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
doPut(Event) - Method in class org.apache.flume.channel.MemoryChannel.MemoryTransaction
 
doRollback() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
doRollback() - Method in class org.apache.flume.channel.MemoryChannel.MemoryTransaction
 
doTake() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
doTake() - Method in class org.apache.flume.channel.MemoryChannel.MemoryTransaction
 
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
 
dumpEvent(Event) - Static method in class org.apache.flume.event.EventHelper
 
dumpEvent(Event, int) - Static method in class org.apache.flume.event.EventHelper
 

E

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
Deprecated.  
equals(ThriftFlumeEvent) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
equals(Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
equals(ThriftFlumeEventServer.append_args) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
equals(Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
equals(ThriftFlumeEventServer.close_args) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
equals(Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
equals(ThriftFlumeEventServer.close_result) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
equals(Object) - Method in class org.apache.flume.sink.hdfs.KerberosUser
 
error - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
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
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_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
 
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
 
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 output formatter.
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
 
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
Deprecated.  
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
 
exists(long) - Method in class org.apache.flume.channel.recoverable.memory.wal.SequenceIDBuffer
 
expandShorthand(char) - Static method in class org.apache.flume.formatter.output.BucketPath
 
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
 
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
Deprecated.  
fieldForId(int) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
fieldForId(int) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
fieldForId(int) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
fields - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
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
 
findByName(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
Deprecated. 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
Deprecated. 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
Deprecated. 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
Deprecated. 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
Deprecated. 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
Deprecated. 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
Deprecated. 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
Deprecated. 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
Deprecated. 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
Deprecated. 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
Deprecated. 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
Deprecated. 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.
firstSeen - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
FlumeConfiguration - Class in org.apache.flume.conf
FlumeConfiguration is an in memory representation of the hierarchical configuration namespace required by the PropertiesFileConfigurationProvider.
FlumeConfiguration(Properties) - 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
 
FlumeFormatter - Interface in org.apache.flume.sink
 
FlumeNode - Class in org.apache.flume.node
 
FlumeNode() - Constructor for class org.apache.flume.node.FlumeNode
 
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.
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.

G

get(int) - Method in class org.apache.flume.channel.recoverable.memory.wal.SequenceIDBuffer
 
get(String) - Method in class org.apache.flume.CounterGroup
 
get(String) - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
 
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
 
getAllChannels() - Method in class org.apache.flume.channel.AbstractChannelSelector
 
getAllChannels() - Method in interface org.apache.flume.ChannelSelector
 
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
 
getArgs() - Method in class org.apache.flume.node.Application
 
getAsyncClient(TNonblockingTransport) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.Factory
Deprecated.  
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().
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
Deprecated.  
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.SimpleEvent
 
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.interceptor.InterceptorType
 
getBuilderClass() - Method in enum org.apache.flume.serialization.EventSerializerType
 
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
 
getBytes(Event) - Method in interface org.apache.flume.sink.FlumeFormatter
 
getBytes(Event) - Method in class org.apache.flume.sink.hdfs.HDFSTextFormatter
 
getBytes(Event) - Method in class org.apache.flume.sink.hdfs.HDFSWritableFormatter
 
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
 
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
 
getChannelFactory() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
getChannelName() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
getChannelProcessor() - Method in class org.apache.flume.source.AbstractSource
 
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.file.SimpleNodeConfiguration
 
getChannels() - Method in class org.apache.flume.conf.source.SourceConfiguration
 
getChannels() - Method in interface org.apache.flume.node.NodeConfiguration
 
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
 
getClient(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client.Factory
Deprecated.  
getClient(TProtocol, TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client.Factory
Deprecated.  
getClientClassName() - Method in enum org.apache.flume.api.RpcClientFactory.ClientType
 
getCode() - Method in enum org.apache.flume.channel.jdbc.TransactionIsolation
 
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
 
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
 
getConfigurationAware() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
getConfigurationErrors() - Method in class org.apache.flume.conf.FlumeConfiguration
 
getConfigurationFor(String) - Method in class org.apache.flume.conf.FlumeConfiguration
 
getConfigurationProvider() - Method in class org.apache.flume.node.FlumeNode
 
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
 
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
 
getData() - Method in class org.apache.flume.channel.recoverable.memory.wal.WALEntry
 
getDate() - Static method in class org.apache.flume.tools.VersionInfo
The date that Flume was compiled.
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.
getDirectMemorySize() - Static method in class org.apache.flume.tools.DirectMemoryUtils
 
getDirectory() - Method in class org.apache.flume.sink.RollingFileSink
 
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
Instead of replacing escape sequences in a string, this method returns a mapping of an attribute name to the value based on the escape sequence found in the argument string.
getEscapeMapping(String, Map<String, String>, boolean, int, int) - Static method in class org.apache.flume.formatter.output.BucketPath
 
getEventAcceptedCount() - Method in class org.apache.flume.instrumentation.SourceCounter
 
getEventAcceptedCount() - Method in interface org.apache.flume.instrumentation.SourceCounterMBean
 
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
 
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
 
getEventSize() - Method in class org.apache.flume.source.SyslogUtils
 
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
Deprecated.  
getFieldName() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
Deprecated.  
getFieldName() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
Deprecated.  
getFieldName() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
Deprecated.  
getFieldName() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
Deprecated.  
getFields() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
getFieldsSize() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
getFieldValue(ThriftFlumeEvent._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
getFieldValue(ThriftFlumeEventServer.append_args._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
getFieldValue(ThriftFlumeEventServer.close_args._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
getFieldValue(ThriftFlumeEventServer.close_result._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
getFile() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
getFileIndex() - Method in class org.apache.flume.formatter.output.PathManager
 
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() - 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.SimpleEvent
 
getHost() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
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
 
getInputProtocol() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
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, 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() - Method in class org.apache.flume.conf.FlumeConfigurationError
 
getKey(Event) - Method in interface org.apache.flume.sink.FlumeFormatter
 
getKey(Event) - Method in class org.apache.flume.sink.hdfs.HDFSTextFormatter
 
getKey(Event) - Method in class org.apache.flume.sink.hdfs.HDFSWritableFormatter
 
getKeyClass() - Method in interface org.apache.flume.sink.FlumeFormatter
 
getKeyClass() - Method in class org.apache.flume.sink.hdfs.HDFSTextFormatter
 
getKeyClass() - Method in class org.apache.flume.sink.hdfs.HDFSWritableFormatter
 
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.
getLifecycleState() - Method in class org.apache.flume.channel.AbstractChannel
 
getLifecycleState() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
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.FlumeNode
 
getLifecycleState() - Method in class org.apache.flume.node.nodemanager.DefaultLogicalNodeManager
 
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.EventDrivenSourceRunner
 
getLifecycleState() - Method in class org.apache.flume.source.PollableSourceRunner
 
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.
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.
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.node.FlumeNode
 
getName() - Method in class org.apache.flume.sink.AbstractSink
 
getName() - Method in class org.apache.flume.source.AbstractSource
 
getNameString() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
 
getNanos() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
getNanoTimestampKey(String) - Static method in class org.apache.flume.sink.hbase.SimpleRowKeyGenerator
 
getNodeManager() - Method in class org.apache.flume.node.FlumeNode
 
getNodeName() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
getNodes() - Method in class org.apache.flume.node.nodemanager.AbstractLogicalNodeManager
 
getNodes() - Method in interface org.apache.flume.node.NodeManager
 
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.
getOutputProtocol() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
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
 
getParameters() - Method in class org.apache.flume.Context
Gets a copy of the backing map structure.
getPolicy() - Method in class org.apache.flume.SinkRunner
 
getPortNumber() - Method in class org.apache.flume.api.HostInfo
 
getPostvalidationConfig() - Method in class org.apache.flume.conf.FlumeConfiguration.AgentConfiguration
 
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
Deprecated.  
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
 
getRandomKey(String) - Static method in class org.apache.flume.sink.hbase.SimpleRowKeyGenerator
 
getReferenceName() - Method in class org.apache.flume.api.HostInfo
 
getRegistryClone() - Method in class org.apache.flume.channel.DefaultChannelFactory
 
getRegistryClone() - Method in class org.apache.flume.sink.DefaultSinkFactory
 
getRegistryClone() - Method in class org.apache.flume.source.DefaultSourceFactory
 
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
Deprecated.  
getResult() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.close_call
Deprecated.  
getResults() - Method in class org.apache.flume.channel.recoverable.memory.wal.WALReplayResult
 
getRevision() - Static method in class org.apache.flume.tools.VersionInfo
Get the subversion revision number for the root directory
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
 
getSequenceID() - Method in class org.apache.flume.channel.recoverable.memory.wal.WALEntry
 
getSequenceID() - Method in class org.apache.flume.channel.recoverable.memory.wal.WALReplayResult
 
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
 
getSinkFactory() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
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 class org.apache.flume.conf.file.SimpleNodeConfiguration
 
getSinkRunners() - Method in interface org.apache.flume.node.NodeConfiguration
 
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
 
getSourceFactory() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
getSourceRunners() - Method in class org.apache.flume.conf.file.SimpleNodeConfiguration
 
getSourceRunners() - Method in interface org.apache.flume.node.NodeConfiguration
 
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.
getStartTime() - Method in interface org.apache.flume.instrumentation.ChannelCounterMBean
 
getStartTime() - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
 
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
 
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.
getSyslogStatus() - Method in enum org.apache.flume.source.SyslogUtils.SyslogStatus
 
getThriftFieldId() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
Deprecated.  
getThriftFieldId() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
Deprecated.  
getThriftFieldId() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
Deprecated.  
getThriftFieldId() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
Deprecated.  
getTimestamp() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
getTimestampKey(String) - Static method in class org.apache.flume.sink.hbase.SimpleRowKeyGenerator
 
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
 
getType() - Method in class org.apache.flume.conf.ComponentConfiguration
 
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.jdbc.impl.PersistableEvent.HeaderEntry
 
getValue(Event) - Method in interface org.apache.flume.sink.FlumeFormatter
 
getValue(Event) - Method in class org.apache.flume.sink.hdfs.HDFSTextFormatter
 
getValue(Event) - Method in class org.apache.flume.sink.hdfs.HDFSWritableFormatter
 
getValueClass() - Method in interface org.apache.flume.sink.FlumeFormatter
 
getValueClass() - Method in class org.apache.flume.sink.hdfs.HDFSTextFormatter
 
getValueClass() - Method in class org.apache.flume.sink.hdfs.HDFSWritableFormatter
 
getValueString() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
 
getVersion() - Static method in class org.apache.flume.tools.VersionInfo
Get the Flume version.
getWriter(String) - Method in class org.apache.flume.sink.hdfs.HDFSWriterFactory
 

H

hashCode() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
hashCode() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
hashCode() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
hashCode() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
hashCode() - Method in class org.apache.flume.sink.hdfs.KerberosUser
 
hasNext() - Method in class org.apache.flume.util.SpecificOrderIterator
 
hasSpill() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.SpillableString
 
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
 
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
 
HDFSFormatterFactory - Class in org.apache.flume.sink.hdfs
 
HDFSSequenceFile - Class in org.apache.flume.sink.hdfs
 
HDFSSequenceFile() - Constructor for class org.apache.flume.sink.hdfs.HDFSSequenceFile
 
HDFSTextFormatter - Class in org.apache.flume.sink.hdfs
 
HDFSTextFormatter() - Constructor for class org.apache.flume.sink.hdfs.HDFSTextFormatter
 
HDFSWritableFormatter - Class in org.apache.flume.sink.hdfs
 
HDFSWritableFormatter() - Constructor for class org.apache.flume.sink.hdfs.HDFSWritableFormatter
 
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_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.
host - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
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
 

I

IGNORE_CASE_CONFIG - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
Whether to ignore case when performing regex matches.
increment(String) - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
 
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
 
INGORE_CASE_DEFAULT - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
 
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.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
 
initialValue() - Method in class org.apache.flume.channel.jdbc.impl.JdbcTransactionFactory
 
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.TimestampInterceptor
Modifies events in-place.
intercept(List<Event>) - Method in class org.apache.flume.interceptor.TimestampInterceptor
Delegates to TimestampInterceptor.intercept(Event) in a loop.
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
 
iprot_ - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
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.
isComponentInErrorState(LifecycleAware) - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
 
isNotFoundConfigClass() - Method in class org.apache.flume.conf.ComponentConfiguration
 
isSet(ThriftFlumeEvent._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated. 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
Deprecated. 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
Deprecated. 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
Deprecated. 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
Deprecated. Returns true if field body is set (has been assigned a value) and false otherwise
isSetEvt() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated. 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
Deprecated. Returns true if field fields is set (has been assigned a value) and false otherwise
isSetHost() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated. Returns true if field host is set (has been assigned a value) and false otherwise
isSetNanos() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated. 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
Deprecated. Returns true if field priority is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated. Returns true if field timestamp is set (has been assigned a value) and false otherwise

J

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
 

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.
KEEPALIVE - Static variable in class org.apache.flume.channel.recoverable.memory.RecoverableMemoryChannel
Deprecated.  
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
 

L

lastSeen - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
lastSeenState - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
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
 
load() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
load() - Method in class org.apache.flume.conf.properties.PropertiesFileConfigurationProvider
 
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.
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
 
LOG_WRITE_TIMEOUT - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
The amount of time in seconds a writer will wait before failing when checkpoint is enqueued or in progress.
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
 
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.recoverable.memory.wal.SequenceIDBuffer
 
main(String[]) - Static method in class org.apache.flume.channel.recoverable.memory.wal.WAL
Reads in a WAL and writes out a new WAL.
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.GetJavaProperty
 
main(String[]) - Static method in class org.apache.flume.tools.VersionInfo
 
MAX_FILE_SIZE - Static variable in class org.apache.flume.channel.file.FileChannelConfiguration
Max file size for data files, cannot exceed the default.
MemoryChannel - Class in org.apache.flume.channel
 
MemoryChannel() - Constructor for class org.apache.flume.channel.MemoryChannel
 
MemoryChannel.MemoryTransaction - Class in org.apache.flume.channel
 
MemoryChannel.MemoryTransaction(int, ChannelCounter) - Constructor for class org.apache.flume.channel.MemoryChannel.MemoryTransaction
 
messageReceived(ChannelHandlerContext, MessageEvent) - Method in class org.apache.flume.source.SyslogTcpSource.syslogTcpHandler
 
messageReceived(ChannelHandlerContext, MessageEvent) - Method in class org.apache.flume.source.SyslogUDPSource.syslogHandler
 
metaDataMap - Static variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
metaDataMap - Static variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
metaDataMap - Static variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
metaDataMap - Static variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
MIN_SIZE - Static variable in class org.apache.flume.source.SyslogUtils
 
MonitoredCounterGroup - Class in org.apache.flume.instrumentation
 
MonitoredCounterGroup(MonitoredCounterGroup.Type, String, String...) - Constructor for class org.apache.flume.instrumentation.MonitoredCounterGroup
 
MonitoredCounterGroup.Type - Enum in org.apache.flume.instrumentation
 
monitorService - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.MonitorRunnable
 
MultiplexingChannelSelector - Class in org.apache.flume.channel
 
MultiplexingChannelSelector() - Constructor for class org.apache.flume.channel.MultiplexingChannelSelector
 
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
Deprecated.  
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.
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.util.SpecificOrderIterator
 
nextFile() - Method in class org.apache.flume.formatter.output.PathManager
 
NodeConfiguration - Interface in org.apache.flume.node
 
NodeConfigurationAware - Interface in org.apache.flume.node.nodemanager
 
NodeManager - Interface in org.apache.flume.node
 
nonce - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
 
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

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. use ConfigurationConstants.CONFIG_CREATE_FK instead.
OLD_CONFIG_CREATE_INDEX - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
Deprecated. use ConfigurationConstants.CONFIG_CREATE_INDEX instead.
OLD_CONFIG_CREATE_SCHEMA - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
Deprecated. use ConfigurationConstants.CONFIG_CREATE_SCHEMA instead.
OLD_CONFIG_DATABASE_TYPE - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
Deprecated. use ConfigurationConstants.CONFIG_DATABASE_TYPE instead.
OLD_CONFIG_JDBC_DRIVER_CLASS - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
Deprecated. use ConfigurationConstants.CONFIG_JDBC_DRIVER_CLASS instead.
OLD_CONFIG_JDBC_PROPS_FILE - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
Deprecated. use ConfigurationConstants.CONFIG_JDBC_PROPS_FILE instead.
OLD_CONFIG_JDBC_SYSPROP_PREFIX - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
Deprecated. use ConfigurationConstants.CONFIG_JDBC_SYSPROP_PREFIX instead
OLD_CONFIG_MAX_CAPACITY - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
Deprecated. use ConfigurationConstants.CONFIG_MAX_CAPACITY instead.
OLD_CONFIG_MAX_CONNECTIONS - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
Deprecated. use ConfigurationConstants.CONFIG_MAX_CONNECTIONS instead
OLD_CONFIG_PASSWORD - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
Deprecated. use ConfigurationConstants.CONFIG_PASSWORD instead.
OLD_CONFIG_TX_ISOLATION_LEVEL - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
Deprecated. use ConfigurationConstants.CONFIG_TX_ISOLATION_LEVEL instead.
OLD_CONFIG_URL - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
Deprecated. use ConfigurationConstants.CONFIG_URL instead.
OLD_CONFIG_USERNAME - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
Deprecated. use ConfigurationConstants.CONFIG_USERNAME instead.
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
 
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
 
onTopic(String, IRCUser, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
open(String, FlumeFormatter) - Method in class org.apache.flume.sink.hdfs.HDFSCompressedDataStream
 
open(String, CompressionCodec, SequenceFile.CompressionType, FlumeFormatter) - Method in class org.apache.flume.sink.hdfs.HDFSCompressedDataStream
 
open(String, FlumeFormatter) - Method in class org.apache.flume.sink.hdfs.HDFSDataStream
 
open(String, CompressionCodec, SequenceFile.CompressionType, FlumeFormatter) - Method in class org.apache.flume.sink.hdfs.HDFSDataStream
 
open(String, FlumeFormatter) - Method in class org.apache.flume.sink.hdfs.HDFSSequenceFile
 
open(String, CompressionCodec, SequenceFile.CompressionType, FlumeFormatter) - Method in class org.apache.flume.sink.hdfs.HDFSSequenceFile
 
open(String, FlumeFormatter) - Method in interface org.apache.flume.sink.hdfs.HDFSWriter
 
open(String, CompressionCodec, SequenceFile.CompressionType, FlumeFormatter) - Method in interface org.apache.flume.sink.hdfs.HDFSWriter
 
oprot_ - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
org.apache.flume - package org.apache.flume
 
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.jdbc - package org.apache.flume.channel.jdbc
 
org.apache.flume.channel.jdbc.impl - package org.apache.flume.channel.jdbc.impl
 
org.apache.flume.channel.recoverable.memory - package org.apache.flume.channel.recoverable.memory
 
org.apache.flume.channel.recoverable.memory.wal - package org.apache.flume.channel.recoverable.memory.wal
 
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.file - package org.apache.flume.conf.file
 
org.apache.flume.conf.properties - package org.apache.flume.conf.properties
 
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.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.node.nodemanager - package org.apache.flume.node.nodemanager
 
org.apache.flume.serialization - package org.apache.flume.serialization
 
org.apache.flume.sink - package org.apache.flume.sink
 
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.source - package org.apache.flume.source
 
org.apache.flume.source.avroLegacy - package org.apache.flume.source.avroLegacy
 
org.apache.flume.source.thriftLegacy - package org.apache.flume.source.thriftLegacy
 
org.apache.flume.tools - package org.apache.flume.tools
 
org.apache.flume.util - package org.apache.flume.util
 

P

parseOptions() - Method in class org.apache.flume.node.Application
 
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.
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
 
PREFIX - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
PRESERVE - Static variable in class org.apache.flume.interceptor.HostInterceptor.Constants
 
PRESERVE - Static variable in class org.apache.flume.interceptor.TimestampInterceptor.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
 
Priority - Enum in com.cloudera.flume.handlers.thrift
 
priority - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
PRIORITY - Static variable in class org.apache.flume.source.avroLegacy.AvroLegacySource
 
process(TProtocol, TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Processor
Deprecated.  
process(int, TProtocol, TProtocol) - Method in interface com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Processor.ProcessFunction
Deprecated.  
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.AvroSink
 
process() - Method in class org.apache.flume.sink.DefaultSinkProcessor
 
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 - take at the most txnEventMax, that's the maximum #events to hold in channel for a given transaction - find the corresponding bucket for the event, ensure the file is open - extract the pay-load and append to HDFS file
WARNING: NOT THREAD SAFE
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() - Method in interface org.apache.flume.SinkProcessor
Handle a request to poll the owned sinks.
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.
processMap_ - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Processor
Deprecated.  
PropertiesFileConfigurationProvider - Class in org.apache.flume.conf.properties
A configuration provider that uses properties file for specifying configuration.
PropertiesFileConfigurationProvider() - Constructor for class org.apache.flume.conf.properties.PropertiesFileConfigurationProvider
 
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.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(int, long) - Method in class org.apache.flume.channel.recoverable.memory.wal.SequenceIDBuffer
 
put(String, String) - Method in class org.apache.flume.Context
Associates the specified value with the specified key in this context.
putAll(Map<String, String>) - Method in class org.apache.flume.Context
Associates all of the given map's keys and values in the Context.
putToFields(String, ByteBuffer) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  

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
 

R

randomKey - Static variable in class org.apache.flume.sink.hbase.RegexHbaseEventSerializer
 
read(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
read(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
read(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
read(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
readFields(DataInput) - Method in class org.apache.flume.channel.recoverable.memory.wal.WALEntry
 
RecoverableMemoryChannel - Class in org.apache.flume.channel.recoverable.memory
Deprecated. The RecoverableMemoryChannel has been deprecated in favor of FileChannel, which gives better performance and is also durable.
RecoverableMemoryChannel() - Constructor for class org.apache.flume.channel.recoverable.memory.RecoverableMemoryChannel
Deprecated.  
recv_close() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
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
 
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
 
releaseProvider(String) - Static method in class org.apache.flume.channel.jdbc.JdbcChannelProviderFactory
 
remove(LifecycleAware) - Method in class org.apache.flume.node.nodemanager.AbstractLogicalNodeManager
 
remove(LifecycleAware) - Method in class org.apache.flume.node.nodemanager.DefaultLogicalNodeManager
 
remove(LifecycleAware) - Method in interface org.apache.flume.node.NodeManager
 
remove() - Method in class org.apache.flume.util.SpecificOrderIterator
 
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.
replaceShorthand(char, Map<String, String>) - Static method in class org.apache.flume.formatter.output.BucketPath
Hardcoded lookups for %x style escape replacement.
replaceShorthand(char, Map<String, String>, boolean, int, int) - Static method in class org.apache.flume.formatter.output.BucketPath
Hardcoded lookups for %x style escape replacement.
replay() - Method in class org.apache.flume.channel.recoverable.memory.wal.WAL
 
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
 
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.
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
 
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.conf.file.AbstractFileConfigurationProvider.FileWatcherRunnable
 
run() - Method in class org.apache.flume.lifecycle.LifecycleSupervisor.MonitorRunnable
 
run() - Method in class org.apache.flume.node.Application
 
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
 

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.
SELECTOR_NAME_RANDOM - Static variable in class org.apache.flume.sink.LoadBalancingSinkProcessor
 
SELECTOR_NAME_ROUND_ROBIN - 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
Deprecated.  
send_close() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
seqid_ - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
SequenceGeneratorSource - Class in org.apache.flume.source
 
SequenceGeneratorSource() - Constructor for class org.apache.flume.source.SequenceGeneratorSource
 
SequenceIDBuffer - Class in org.apache.flume.channel.recoverable.memory.wal
 
SequenceIDBuffer(int) - Constructor for class org.apache.flume.channel.recoverable.memory.wal.SequenceIDBuffer
 
set(String, Long) - Method in class org.apache.flume.CounterGroup
 
set(String, long) - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
 
setArgs(String[]) - Method in class org.apache.flume.node.Application
 
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
Deprecated.  
setBody(ByteBuffer) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setBody(byte[]) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
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
 
setBodyIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
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
setChannelFactory(ChannelFactory) - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
setChannelProcessor(ChannelProcessor) - Method in class org.apache.flume.source.AbstractSource
 
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
 
setChannels(Map<String, Channel>) - Method in class org.apache.flume.conf.file.SimpleNodeConfiguration
 
setChannelSize(long) - Method in class org.apache.flume.instrumentation.ChannelCounter
 
setConfigurationAware(NodeConfigurationAware) - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
setConfigurationProvider(ConfigurationProvider) - Method in class org.apache.flume.node.FlumeNode
 
setConfigured() - Method in class org.apache.flume.conf.ComponentConfiguration
 
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
 
setEvent(Event) - Method in interface org.apache.flume.sink.hbase.AsyncHbaseEventSerializer
 
setEvent(Event) - Method in class org.apache.flume.sink.hbase.SimpleAsyncHbaseEventSerializer
 
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
 
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
Deprecated.  
setEvtIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
setFields(Map<String, ByteBuffer>) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setFieldsIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setFieldValue(ThriftFlumeEvent._Fields, Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setFieldValue(ThriftFlumeEventServer.append_args._Fields, Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
setFieldValue(ThriftFlumeEventServer.close_args._Fields, Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
setFieldValue(ThriftFlumeEventServer.close_result._Fields, Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
setFile(File) - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
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(Map<String, String>) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
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
 
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
Deprecated.  
setHostIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
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
 
setId(long) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
 
setInterceptors(List<Interceptor>) - Method in class org.apache.flume.interceptor.InterceptorChain
 
setMaxLogsSize(long) - Method in class org.apache.flume.channel.recoverable.memory.wal.WAL
 
setMinLogRetentionPeriod(long) - Method in class org.apache.flume.channel.recoverable.memory.wal.WAL
 
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.node.FlumeNode
 
setName(String) - Method in class org.apache.flume.sink.AbstractSink
 
setName(String) - Method in class org.apache.flume.source.AbstractSource
 
setNanos(long) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setNanosIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setNodeManager(NodeManager) - Method in class org.apache.flume.node.FlumeNode
 
setNodeName(String) - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
setNodes(Set<LifecycleAware>) - Method in class org.apache.flume.node.nodemanager.AbstractLogicalNodeManager
 
setNodes(Set<LifecycleAware>) - Method in interface org.apache.flume.node.NodeManager
 
setNotFoundConfigClass() - Method in class org.apache.flume.conf.ComponentConfiguration
 
setPort(int) - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
Set the port on the hostname to connect to.
setPriority(Priority) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setPriorityIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setProcessorContext(Context) - Method in class org.apache.flume.conf.sink.SinkGroupConfiguration
 
setRollInterval(long) - Method in class org.apache.flume.sink.RollingFileSink
 
setRollSize(long) - Method in class org.apache.flume.channel.recoverable.memory.wal.WAL
 
setSink(SinkProcessor) - Method in class org.apache.flume.SinkRunner
 
setSinkFactory(SinkFactory) - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
setSinkProcessorConfiguration(SinkProcessorConfiguration) - Method in class org.apache.flume.conf.sink.SinkGroupConfiguration
 
setSinkRunners(Map<String, SinkRunner>) - Method in class org.apache.flume.conf.file.SimpleNodeConfiguration
 
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
 
setSourceFactory(SourceFactory) - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
setSourceRunners(Map<String, SourceRunner>) - Method in class org.apache.flume.conf.file.SimpleNodeConfiguration
 
setSpillPayload(byte[]) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
 
setTimestamp(long) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setTimestampIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setType(String) - Method in class org.apache.flume.conf.ComponentConfiguration
 
setWorkerInterval(long) - Method in class org.apache.flume.channel.recoverable.memory.wal.WAL
 
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
 
SimpleNodeConfiguration - Class in org.apache.flume.conf.file
 
SimpleNodeConfiguration() - Constructor for class org.apache.flume.conf.file.SimpleNodeConfiguration
 
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
 
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
 
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
 
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 - Variable in class org.apache.flume.conf.sink.SinkProcessorConfiguration
 
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.channel.recoverable.memory.wal.SequenceIDBuffer
 
sort() - Method in class org.apache.flume.channel.recoverable.memory.wal.SequenceIDBuffer
 
Source - Interface in org.apache.flume
A source generates and calls methods on the configured ChannelProcessor to persist those events into the configured channels.
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
 
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
 
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.recoverable.memory.RecoverableMemoryChannel
Deprecated.  
start() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
start() - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
 
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.FlumeNode
 
start() - Method in class org.apache.flume.node.nodemanager.DefaultLogicalNodeManager
 
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.AvroSink
The start() of AvroSink 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.DefaultSinkProcessor
 
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.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.EventDrivenSourceRunner
 
start() - Method in class org.apache.flume.source.ExecSource
 
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.SequenceGeneratorSource
 
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_OR_ERROR - Static variable in enum org.apache.flume.lifecycle.LifecycleState
 
startAllComponents(NodeConfiguration) - Method in class org.apache.flume.node.nodemanager.DefaultLogicalNodeManager
 
startAllComponents(NodeConfiguration) - Method in interface org.apache.flume.node.nodemanager.NodeConfigurationAware
Start components with the configuration provided.
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.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.recoverable.memory.RecoverableMemoryChannel
Deprecated.  
stop() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
stop() - Method in class org.apache.flume.instrumentation.MonitoredCounterGroup
 
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.FlumeNode
 
stop() - Method in class org.apache.flume.node.nodemanager.DefaultLogicalNodeManager
 
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.AvroSink
 
stop() - Method in class org.apache.flume.sink.DefaultSinkProcessor
 
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 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.EventDrivenSourceRunner
 
stop() - Method in class org.apache.flume.source.ExecSource
 
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.SequenceGeneratorSource
 
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_OR_ERROR - Static variable in enum org.apache.flume.lifecycle.LifecycleState
 
stopAll(List<LifecycleAware>) - Static method in class org.apache.flume.lifecycle.LifecycleController
 
stopAllComponents() - Method in class org.apache.flume.node.nodemanager.DefaultLogicalNodeManager
 
stopAllComponents() - Method in interface org.apache.flume.node.nodemanager.NodeConfigurationAware
Stop all components currently running.
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.
StressSource - Class in org.apache.flume.source
 
StressSource() - Constructor for class org.apache.flume.source.StressSource
 
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.
swap(int, int) - Method in class org.apache.flume.channel.recoverable.memory.wal.SequenceIDBuffer
 
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
 
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) - 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
 

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.
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
Deprecated. 
ThriftFlumeEvent() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
ThriftFlumeEvent(long, Priority, ByteBuffer, long, String, Map<String, ByteBuffer>) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
ThriftFlumeEvent(ThriftFlumeEvent) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated. Performs a deep copy on other.
ThriftFlumeEvent._Fields - Enum in com.cloudera.flume.handlers.thrift
Deprecated. The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftFlumeEventServer - Class in com.cloudera.flume.handlers.thrift
Deprecated. 
ThriftFlumeEventServer() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer
Deprecated.  
ThriftFlumeEventServer.append_args - Class in com.cloudera.flume.handlers.thrift
Deprecated.  
ThriftFlumeEventServer.append_args() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
ThriftFlumeEventServer.append_args(ThriftFlumeEvent) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
ThriftFlumeEventServer.append_args(ThriftFlumeEventServer.append_args) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated. Performs a deep copy on other.
ThriftFlumeEventServer.append_args._Fields - Enum in com.cloudera.flume.handlers.thrift
Deprecated. 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
Deprecated.  
ThriftFlumeEventServer.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient
Deprecated.  
ThriftFlumeEventServer.AsyncClient.append_call - Class in com.cloudera.flume.handlers.thrift
Deprecated.  
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
Deprecated.  
ThriftFlumeEventServer.AsyncClient.close_call - Class in com.cloudera.flume.handlers.thrift
Deprecated.  
ThriftFlumeEventServer.AsyncClient.close_call(AsyncMethodCallback<ThriftFlumeEventServer.AsyncClient.close_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.close_call
Deprecated.  
ThriftFlumeEventServer.AsyncClient.Factory - Class in com.cloudera.flume.handlers.thrift
Deprecated.  
ThriftFlumeEventServer.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.Factory
Deprecated.  
ThriftFlumeEventServer.AsyncIface - Interface in com.cloudera.flume.handlers.thrift
Deprecated.  
ThriftFlumeEventServer.Client - Class in com.cloudera.flume.handlers.thrift
Deprecated.  
ThriftFlumeEventServer.Client(TProtocol) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
ThriftFlumeEventServer.Client(TProtocol, TProtocol) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
ThriftFlumeEventServer.Client.Factory - Class in com.cloudera.flume.handlers.thrift
Deprecated.  
ThriftFlumeEventServer.Client.Factory() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client.Factory
Deprecated.  
ThriftFlumeEventServer.close_args - Class in com.cloudera.flume.handlers.thrift
Deprecated.  
ThriftFlumeEventServer.close_args() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
ThriftFlumeEventServer.close_args(ThriftFlumeEventServer.close_args) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated. Performs a deep copy on other.
ThriftFlumeEventServer.close_args._Fields - Enum in com.cloudera.flume.handlers.thrift
Deprecated. 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
Deprecated.  
ThriftFlumeEventServer.close_result() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
ThriftFlumeEventServer.close_result(ThriftFlumeEventServer.close_result) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated. Performs a deep copy on other.
ThriftFlumeEventServer.close_result._Fields - Enum in com.cloudera.flume.handlers.thrift
Deprecated. 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
Deprecated.  
ThriftFlumeEventServer.Processor - Class in com.cloudera.flume.handlers.thrift
Deprecated.  
ThriftFlumeEventServer.Processor(ThriftFlumeEventServer.Iface) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Processor
Deprecated.  
ThriftFlumeEventServer.Processor.ProcessFunction - Interface in com.cloudera.flume.handlers.thrift
Deprecated.  
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
 
timestamp - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
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
 
toString() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
toString() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
toString() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
toString() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
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.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() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
toString() - Method in class org.apache.flume.conf.file.SimpleNodeConfiguration
 
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.FlumeNode
 
toString() - Method in class org.apache.flume.node.nodemanager.AbstractLogicalNodeManager
 
toString() - Method in class org.apache.flume.sink.AvroSink
 
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.SinkRunner
 
toString() - Method in class org.apache.flume.source.AvroSource
 
toString() - Method in class org.apache.flume.source.EventDrivenSourceRunner
 
toString() - Method in class org.apache.flume.source.PollableSourceRunner
 
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.
TransactionIsolation - Enum in org.apache.flume.channel.jdbc
 

U

unknown(String, String, String, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
unregister(Channel) - Method in class org.apache.flume.channel.DefaultChannelFactory
 
unregister(Channel) - Method in interface org.apache.flume.ChannelFactory
 
unregister(Sink) - Method in class org.apache.flume.sink.DefaultSinkFactory
 
unregister(Sink) - Method in interface org.apache.flume.SinkFactory
 
unregister(Source) - Method in class org.apache.flume.source.DefaultSourceFactory
 
unregister(Source) - Method in interface org.apache.flume.SourceFactory
 
unsetBody() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
unsetEvt() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
unsetFields() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
unsetHost() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
unsetNanos() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
unsetPriority() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
unsetTimestamp() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
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_IP - Static variable in class org.apache.flume.interceptor.HostInterceptor.Constants
 
USE_IP_DFLT - Static variable in class org.apache.flume.interceptor.HostInterceptor.Constants
 

V

validate() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
validate() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
validate() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
validate() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
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.
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
Deprecated. 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
Deprecated. 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
Deprecated. 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
Deprecated. 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.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.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.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.Status
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.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
Deprecated. 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
Deprecated. 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
Deprecated. 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
Deprecated. 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.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.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.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.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.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.Transaction.TransactionState
Returns an array containing the constants of this enum type, in the order they are declared.
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
 
WAL<T extends org.apache.hadoop.io.Writable> - Class in org.apache.flume.channel.recoverable.memory.wal
Provides Write Ahead Log functionality for a generic Writable.
WAL(File, Class<T>, long, long, long, long) - Constructor for class org.apache.flume.channel.recoverable.memory.wal.WAL
Creates a wal object with no defaults, using the specified parameters in the constructor for operation.
WAL_DATA_DIR - Static variable in class org.apache.flume.channel.recoverable.memory.RecoverableMemoryChannel
Deprecated.  
WAL_MAX_LOGS_SIZE - Static variable in class org.apache.flume.channel.recoverable.memory.RecoverableMemoryChannel
Deprecated.  
WAL_MIN_RETENTION_PERIOD - Static variable in class org.apache.flume.channel.recoverable.memory.RecoverableMemoryChannel
Deprecated.  
WAL_ROLL_SIZE - Static variable in class org.apache.flume.channel.recoverable.memory.RecoverableMemoryChannel
Deprecated.  
WAL_WORKER_INTERVAL - Static variable in class org.apache.flume.channel.recoverable.memory.RecoverableMemoryChannel
Deprecated.  
WALEntry<T extends org.apache.hadoop.io.Writable> - Class in org.apache.flume.channel.recoverable.memory.wal
Wraps a Writable with a sequence id so that both can be written together to a file.
WALEntry(T, long) - Constructor for class org.apache.flume.channel.recoverable.memory.wal.WALEntry
Creates a WALEntry with specified payload and sequence id
WALReplayResult<T extends org.apache.hadoop.io.Writable> - Class in org.apache.flume.channel.recoverable.memory.wal
 
WALReplayResult(List<WALEntry<T>>, long) - Constructor for class org.apache.flume.channel.recoverable.memory.wal.WALReplayResult
 
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
Deprecated.  
write(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
write(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
write(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
write(DataOutput) - Method in class org.apache.flume.channel.recoverable.memory.wal.WALEntry
 
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_args(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.append_call
Deprecated.  
write_args(TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.close_call
Deprecated.  
writeEntries(List<WALEntry<T>>) - Method in class org.apache.flume.channel.recoverable.memory.wal.WAL
 
writeEntry(WALEntry<T>) - Method in class org.apache.flume.channel.recoverable.memory.wal.WAL
 
writeSequenceID(long) - Method in class org.apache.flume.channel.recoverable.memory.wal.WAL
 
writeSequenceIDs(List<Long>) - Method in class org.apache.flume.channel.recoverable.memory.wal.WAL
 

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

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